2025.06.13 08:41:10.262774 [ 398 ] {} Context: Server was built with memory sanitizer. It will work slowly. 2025.06.13 08:41:12.334623 [ 410 ] {} CgroupsReader: Cannot find 'kernel' in '/sys/fs/cgroup/memory.stat' 2025.06.13 08:41:12.920266 [ 398 ] {} KeeperLogStore: No logs exists in /var/lib/clickhouse/coordination/logs. It's Ok if it's the first run of clickhouse-keeper. 2025.06.13 08:41:12.921855 [ 398 ] {} KeeperLogStore: Removing all changelogs 2025.06.13 08:41:12.923773 [ 398 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.06.13 08:41:12.933694 [ 398 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.06.13 08:41:12.933782 [ 398 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.06.13 08:41:12.985120 [ 992 ] {} RaftInstance: Election timeout, initiate leader election 2025.06.13 08:41:13.102021 [ 398 ] {} Access(local_directory): File /var/lib/clickhouse/access/users.list doesn't exist 2025.06.13 08:41:13.102107 [ 398 ] {} Access(local_directory): Recovering lists in directory /var/lib/clickhouse/access/ 2025.06.13 08:41:13.139615 [ 398 ] {} Context: Delay accounting is not enabled, OSIOWaitMicroseconds will not be gathered. You can enable it using `echo 1 > /proc/sys/kernel/task_delayacct` or by using sysctl. 2025.06.13 08:41:13.141805 [ 398 ] {} Context: The setting 'allow_remote_fs_zero_copy_replication' is enabled for MergeTree tables. But the feature of 'zero-copy replication' is under development and is not ready for production. The usage of this feature can lead to data corruption and loss. The setting should be disabled in production. 2025.06.13 08:41:32.574749 [ 404 ] {8e6d2f14-aa54-49dc-8e30-6e894fed0711} InterpreterCreateQuery: ATTACH TABLE query with full table definition is not recommended: use either ATTACH TABLE hits_v1; to attach existing table or CREATE TABLE hits_v1 ; to create new table or ATTACH TABLE hits_v1 FROM '/path/to/data/'
; to create new table and attach data. 2025.06.13 08:41:43.118229 [ 404 ] {0c6ae40a-3cf4-4f3e-96ca-ac5686a980ae} InterpreterCreateQuery: ATTACH TABLE query with full table definition is not recommended: use either ATTACH TABLE visits_v1; to attach existing table or CREATE TABLE visits_v1
; to create new table or ATTACH TABLE visits_v1 FROM '/path/to/data/'
; to create new table and attach data. 2025.06.13 08:44:15.135532 [ 404 ] {5927f2b8-b4bd-44f2-949e-5152e05d23c3} executeQuery: Code: 48. DB::Exception: Table engine View doesn't support mutations. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49498) (comment: 01745_alter_delete_view.sql) (query 7, line 23) (in query: ALTER TABLE test_view DELETE WHERE pk = 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::IStorage::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x000000003824f54e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:233: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032895217 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:44:15.147681 [ 404 ] {} TCPHandler: Code: 48. DB::Exception: Table engine View doesn't support mutations. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::IStorage::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x000000003824f54e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:233: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032895217 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:44:17.557258 [ 2135 ] {515e8f91-ca19-400e-9475-4ed8e38c9554} StorageBuffer (test_bl1elt7j.buffer_table1__fuzz_24): Destination table test_bl1elt7j.merge_tree_table1 doesn't have column s. The default values are used. 2025.06.13 08:44:17.557482 [ 2135 ] {515e8f91-ca19-400e-9475-4ed8e38c9554} StorageBuffer (test_bl1elt7j.buffer_table1__fuzz_24): Destination table test_bl1elt7j.merge_tree_table1 has no common columns with block in buffer. Block of data is skipped. 2025.06.13 08:44:17.901793 [ 2135 ] {515e8f91-ca19-400e-9475-4ed8e38c9554} executeQuery: Code: 59. DB::Exception: Illegal type Nullable(UInt64) of column _CAST(3628800_Nullable(UInt64), 'Nullable(UInt64)'_String) for filter. Must be UInt8 or Nullable(UInt8). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49606) (comment: 00910_buffer_prewhere_different_types.sql) (query 5, line 7) (in query: SELECT s FROM buffer_table1__fuzz_24 PREWHERE factorial(toNullable(10));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a1f836d 4. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:51: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003ba1825d 5. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:71: DB::FilterTransform::FilterTransform(DB::Block const&, std::shared_ptr, String, bool, bool, std::shared_ptr>, std::optional) @ 0x000000003ba1866f 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::FilterTransform* std::construct_at[abi:ne190107]&, String&, bool&, DB::FilterTransform*>(DB::FilterTransform*, DB::Block const&, std::shared_ptr&, String&, bool&) @ 0x0000000032ab1793 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::shared_ptr std::__function::__policy_invoker (DB::Block const&)>::__call_impl[abi:ne190107]> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long)::$_3, std::shared_ptr (DB::Block const&)>>(std::__function::__policy_storage const*, DB::Block const&) @ 0x0000000038eb84e5 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f13cf0e 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f132626 10. ./build_docker/./src/QueryPipeline/Pipe.cpp:632: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f131799 11. ./build_docker/./src/QueryPipeline/Pipe.cpp:642: DB::Pipe::addSimpleTransform(std::function (DB::Block const&)> const&) @ 0x000000002f133943 12. ./build_docker/./src/Storages/StorageBuffer.cpp:492: DB::StorageBuffer::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038e9facc 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032b6f004 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032b5101c 15. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x0000000032afc62e 16. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:44:17.917976 [ 2135 ] {} TCPHandler: Code: 59. DB::Exception: Illegal type Nullable(UInt64) of column _CAST(3628800_Nullable(UInt64), 'Nullable(UInt64)'_String) for filter. Must be UInt8 or Nullable(UInt8). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a1f836d 4. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:51: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003ba1825d 5. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:71: DB::FilterTransform::FilterTransform(DB::Block const&, std::shared_ptr, String, bool, bool, std::shared_ptr>, std::optional) @ 0x000000003ba1866f 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::FilterTransform* std::construct_at[abi:ne190107]&, String&, bool&, DB::FilterTransform*>(DB::FilterTransform*, DB::Block const&, std::shared_ptr&, String&, bool&) @ 0x0000000032ab1793 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::shared_ptr std::__function::__policy_invoker (DB::Block const&)>::__call_impl[abi:ne190107]> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long)::$_3, std::shared_ptr (DB::Block const&)>>(std::__function::__policy_storage const*, DB::Block const&) @ 0x0000000038eb84e5 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f13cf0e 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f132626 10. ./build_docker/./src/QueryPipeline/Pipe.cpp:632: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f131799 11. ./build_docker/./src/QueryPipeline/Pipe.cpp:642: DB::Pipe::addSimpleTransform(std::function (DB::Block const&)> const&) @ 0x000000002f133943 12. ./build_docker/./src/Storages/StorageBuffer.cpp:492: DB::StorageBuffer::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038e9facc 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032b6f004 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032b5101c 15. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x0000000032afc62e 16. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:44:18.035762 [ 2135 ] {691bf439-e373-4aa5-811a-d365b0576532} StorageBuffer (test_bl1elt7j.buffer_table1__fuzz_24): Destination table test_bl1elt7j.merge_tree_table1 doesn't have column s. The default values are used. 2025.06.13 08:44:18.035900 [ 2135 ] {691bf439-e373-4aa5-811a-d365b0576532} StorageBuffer (test_bl1elt7j.buffer_table1__fuzz_24): Destination table test_bl1elt7j.merge_tree_table1 has no common columns with block in buffer. Block of data is skipped. 2025.06.13 08:44:18.038882 [ 2135 ] {691bf439-e373-4aa5-811a-d365b0576532} executeQuery: Code: 59. DB::Exception: Illegal type Nullable(UInt64) of column _CAST(3628800_Nullable(UInt64), 'Nullable(UInt64)'_String) for filter. Must be UInt8 or Nullable(UInt8). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49606) (comment: 00910_buffer_prewhere_different_types.sql) (query 7, line 11) (in query: SELECT s FROM buffer_table1__fuzz_24 PREWHERE factorial(toNullable(10));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a1f836d 4. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:51: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003ba1825d 5. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:71: DB::FilterTransform::FilterTransform(DB::Block const&, std::shared_ptr, String, bool, bool, std::shared_ptr>, std::optional) @ 0x000000003ba1866f 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::FilterTransform* std::construct_at[abi:ne190107]&, String&, bool&, DB::FilterTransform*>(DB::FilterTransform*, DB::Block const&, std::shared_ptr&, String&, bool&) @ 0x0000000032ab1793 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::shared_ptr std::__function::__policy_invoker (DB::Block const&)>::__call_impl[abi:ne190107]> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long)::$_3, std::shared_ptr (DB::Block const&)>>(std::__function::__policy_storage const*, DB::Block const&) @ 0x0000000038eb84e5 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f13cf0e 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f132626 10. ./build_docker/./src/QueryPipeline/Pipe.cpp:632: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f131799 11. ./build_docker/./src/QueryPipeline/Pipe.cpp:642: DB::Pipe::addSimpleTransform(std::function (DB::Block const&)> const&) @ 0x000000002f133943 12. ./build_docker/./src/Storages/StorageBuffer.cpp:492: DB::StorageBuffer::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038e9facc 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032b6f004 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032b5101c 15. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x0000000032afc62e 16. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:44:18.040392 [ 2135 ] {} TCPHandler: Code: 59. DB::Exception: Illegal type Nullable(UInt64) of column _CAST(3628800_Nullable(UInt64), 'Nullable(UInt64)'_String) for filter. Must be UInt8 or Nullable(UInt8). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a1f836d 4. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:51: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003ba1825d 5. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:71: DB::FilterTransform::FilterTransform(DB::Block const&, std::shared_ptr, String, bool, bool, std::shared_ptr>, std::optional) @ 0x000000003ba1866f 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::FilterTransform* std::construct_at[abi:ne190107]&, String&, bool&, DB::FilterTransform*>(DB::FilterTransform*, DB::Block const&, std::shared_ptr&, String&, bool&) @ 0x0000000032ab1793 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::shared_ptr std::__function::__policy_invoker (DB::Block const&)>::__call_impl[abi:ne190107]> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long)::$_3, std::shared_ptr (DB::Block const&)>>(std::__function::__policy_storage const*, DB::Block const&) @ 0x0000000038eb84e5 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f13cf0e 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f132626 10. ./build_docker/./src/QueryPipeline/Pipe.cpp:632: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f131799 11. ./build_docker/./src/QueryPipeline/Pipe.cpp:642: DB::Pipe::addSimpleTransform(std::function (DB::Block const&)> const&) @ 0x000000002f133943 12. ./build_docker/./src/Storages/StorageBuffer.cpp:492: DB::StorageBuffer::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038e9facc 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032b6f004 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032b5101c 15. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x0000000032afc62e 16. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:44:18.093123 [ 2135 ] {68ae6fdf-683e-402d-8028-de9e3e5aab95} StorageBuffer (test_bl1elt7j.buffer_table1__fuzz_28): Destination table test_bl1elt7j.merge_tree_table1 has different type of column x (UInt32 != Nullable(UInt32)). Data from destination table are converted. 2025.06.13 08:44:18.194748 [ 2135 ] {1a4c0d1d-9eb3-4d12-b756-0cb3aee21237} StorageBuffer (test_bl1elt7j.buffer_table1__fuzz_28): Destination table test_bl1elt7j.merge_tree_table1 has different type of column x (UInt32 != Nullable(UInt32)). Data from destination table are converted. 2025.06.13 08:44:19.790250 [ 404 ] {56ec42f9-3e0e-45e8-b59a-0739c5cc0fb6} executeQuery: Code: 36. DB::Exception: Lambda lambda(tuple(1), 1) argument is not identifier. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49682) (comment: 03392_inconsistent_formatting_of_lambda.sql) (query 1, line 1) (in query: SELECT lambda(tuple(1), 1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:648: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x00000000302680aa 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:588: DB::(anonymous namespace)::QueryTreeBuilder::buildExpressionList(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030260ffc 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:339: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030275833 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003025ed8a 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003026a541 9. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003025ea82 10. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000003025d3c8 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae30f2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:44:19.792210 [ 404 ] {} TCPHandler: Code: 36. DB::Exception: Lambda lambda(tuple(1), 1) argument is not identifier. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:648: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x00000000302680aa 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:588: DB::(anonymous namespace)::QueryTreeBuilder::buildExpressionList(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030260ffc 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:339: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030275833 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003025ed8a 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003026a541 9. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003025ea82 10. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000003025d3c8 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae30f2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:44:19.809839 [ 404 ] {7ed599d3-3df0-4e38-89ef-b38ab82db022} executeQuery: Code: 36. DB::Exception: Lambda lambda((1, 2), materialize(1) + x) argument is not identifier. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49682) (comment: 03392_inconsistent_formatting_of_lambda.sql) (query 2, line 2) (in query: SELECT lambda(tuple(1, 2), materialize(1) + x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:648: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x00000000302680aa 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:588: DB::(anonymous namespace)::QueryTreeBuilder::buildExpressionList(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030260ffc 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:339: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030275833 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003025ed8a 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003026a541 9. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003025ea82 10. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000003025d3c8 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae30f2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:44:19.811020 [ 404 ] {} TCPHandler: Code: 36. DB::Exception: Lambda lambda((1, 2), materialize(1) + x) argument is not identifier. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:648: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x00000000302680aa 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:588: DB::(anonymous namespace)::QueryTreeBuilder::buildExpressionList(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030260ffc 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:339: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030275833 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003025ed8a 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003026a541 9. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003025ea82 10. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000003025d3c8 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae30f2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:44:21.905684 [ 2135 ] {c4f6560a-638f-4951-a660-f6b2da4e6379} executeQuery: Code: 446. DB::Exception: The function getClientHTTPHeader requires setting `allow_get_client_http_header` to be enabled. (FUNCTION_NOT_ALLOWED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48642) (comment: 03021_get_client_http_header.sh) (in query: SELECT getClientHTTPHeader(arrayJoin(['Content-Type', 'Accept']))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl[abi:ne190107] (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x000000000f06bfbc 5. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl[abi:ne190107] (std::shared_ptr)>, DB::FunctionDocumentation, DB::IFactoryWithAliases (std::shared_ptr)>, DB::FunctionDocumentation>>::Case)::$_0, std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x000000002c023624 6. DB::FunctionFactory::tryGetImpl(String const&, std::shared_ptr) const @ 0x000000002c020e4b 7. DB::FunctionFactory::tryGet(String const&, std::shared_ptr) const @ 0x000000002c022dec 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3313: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037dd3a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 23. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 24. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 25. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:44:21.910847 [ 2135 ] {c4f6560a-638f-4951-a660-f6b2da4e6379} DynamicQueryHandler: Code: 446. DB::Exception: The function getClientHTTPHeader requires setting `allow_get_client_http_header` to be enabled. (FUNCTION_NOT_ALLOWED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl[abi:ne190107] (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x000000000f06bfbc 5. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl[abi:ne190107] (std::shared_ptr)>, DB::FunctionDocumentation, DB::IFactoryWithAliases (std::shared_ptr)>, DB::FunctionDocumentation>>::Case)::$_0, std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x000000002c023624 6. DB::FunctionFactory::tryGetImpl(String const&, std::shared_ptr) const @ 0x000000002c020e4b 7. DB::FunctionFactory::tryGet(String const&, std::shared_ptr) const @ 0x000000002c022dec 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3313: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037dd3a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 23. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 24. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 25. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:44:21.929673 [ 2135 ] {0edb54c8-b3ea-483b-8797-2b5f5022205e} executeQuery: Code: 446. DB::Exception: The function getClientHTTPHeader requires setting `allow_get_client_http_header` to be enabled. (FUNCTION_NOT_ALLOWED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48654) (comment: 03021_get_client_http_header.sh) (in query: SELECT getClientHTTPHeader(arrayJoin(['Content-Type', 'Accept']))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl[abi:ne190107] (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x000000000f06bfbc 5. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl[abi:ne190107] (std::shared_ptr)>, DB::FunctionDocumentation, DB::IFactoryWithAliases (std::shared_ptr)>, DB::FunctionDocumentation>>::Case)::$_0, std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x000000002c023624 6. DB::FunctionFactory::tryGetImpl(String const&, std::shared_ptr) const @ 0x000000002c020e4b 7. DB::FunctionFactory::tryGet(String const&, std::shared_ptr) const @ 0x000000002c022dec 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3313: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037dd3a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 23. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 24. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 25. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:44:21.930672 [ 2135 ] {0edb54c8-b3ea-483b-8797-2b5f5022205e} DynamicQueryHandler: Code: 446. DB::Exception: The function getClientHTTPHeader requires setting `allow_get_client_http_header` to be enabled. (FUNCTION_NOT_ALLOWED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl[abi:ne190107] (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x000000000f06bfbc 5. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl[abi:ne190107] (std::shared_ptr)>, DB::FunctionDocumentation, DB::IFactoryWithAliases (std::shared_ptr)>, DB::FunctionDocumentation>>::Case)::$_0, std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x000000002c023624 6. DB::FunctionFactory::tryGetImpl(String const&, std::shared_ptr) const @ 0x000000002c020e4b 7. DB::FunctionFactory::tryGet(String const&, std::shared_ptr) const @ 0x000000002c022dec 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3313: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037dd3a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 23. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 24. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 25. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:44:23.831948 [ 2142 ] {dfe15889-a2fd-4105-8159-1ec279bbbfa7} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.04 MiB (attempt to allocate chunk of 1.04 MiB bytes), maximum: 976.56 KiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:55906) (comment: 00133_long_shard_memory_tracker_and_exception_safety.sh) (query 1, line 2) (in query: DESC TABLE test_kuhweop8.numbers_100k), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f53cbed 8. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f87f7ca 9. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dc0c59d 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003ae044f8 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003adea5d3 12. ./build_docker/./src/Server/TCPHandler.cpp:2445: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade0fba 13. ./build_docker/./src/Server/TCPHandler.cpp:1224: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe135 14. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:44:23.855021 [ 2142 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.04 MiB (attempt to allocate chunk of 1.04 MiB bytes), maximum: 976.56 KiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f53cbed 8. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f87f7ca 9. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dc0c59d 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003ae044f8 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003adea5d3 12. ./build_docker/./src/Server/TCPHandler.cpp:2445: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade0fba 13. ./build_docker/./src/Server/TCPHandler.cpp:1224: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe135 14. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:44:23.979564 [ 404 ] {f0f2b00a-b43f-4ccb-9975-1a55985f8393} executeQuery: Code: 241. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Query memory limit exceeded: would use 1.04 MiB (attempt to allocate chunk of 1.04 MiB bytes), maximum: 976.56 KiB.. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f53cbed 8. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f87f7ca 9. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dc0c59d 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003ae044f8 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003adea5d3 12. ./build_docker/./src/Server/TCPHandler.cpp:2445: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade0fba 13. ./build_docker/./src/Server/TCPHandler.cpp:1224: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe135 14. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 . (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59396) (comment: 00133_long_shard_memory_tracker_and_exception_safety.sh) (query 1, line 2) (in query: SELECT intDiv(number, 5) AS k, max(toString(number)) FROM remote('127.0.0.{2,3}', test_kuhweop8.numbers_100k) GROUP BY k ORDER BY k LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f893977 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003a97bf4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003a99a03b 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aa95398 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 2025.06.13 08:44:23.985466 [ 404 ] {} TCPHandler: Code: 241. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Query memory limit exceeded: would use 1.04 MiB (attempt to allocate chunk of 1.04 MiB bytes), maximum: 976.56 KiB.. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f53cbed 8. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f87f7ca 9. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dc0c59d 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003ae044f8 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003adea5d3 12. ./build_docker/./src/Server/TCPHandler.cpp:2445: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade0fba 13. ./build_docker/./src/Server/TCPHandler.cpp:1224: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe135 14. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 . (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f893977 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003a97bf4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003a99a03b 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aa95398 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 2025.06.13 08:44:25.185453 [ 2084 ] {bda3944d-47ff-47aa-85e9-2796423d27db} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 2.32 MiB (attempt to allocate chunk of 1.00 MiB bytes), maximum: 1.43 MiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59470) (comment: 00133_long_shard_memory_tracker_and_exception_safety.sh) (query 1, line 2) (in query: SELECT intDiv(number, 5) AS k, max(toString(number)) FROM remote('127.0.0.{2,3}', test_kuhweop8.numbers_100k) GROUP BY k ORDER BY k LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f53cbed 8. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f87f7ca 9. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fbc9cb5 10. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fbca326 11. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003a9b529c 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:21: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, unsigned long) @ 0x000000003a9b520b 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003a962bc6 14. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x000000003a97cef3 15. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x000000003a9c8ba7 16. ./build_docker/./src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x000000003a9cef80 17. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 18. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 19. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 2025.06.13 08:44:25.191814 [ 2084 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 2.32 MiB (attempt to allocate chunk of 1.00 MiB bytes), maximum: 1.43 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f53cbed 8. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f87f7ca 9. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fbc9cb5 10. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fbca326 11. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003a9b529c 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:21: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, unsigned long) @ 0x000000003a9b520b 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003a962bc6 14. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x000000003a97cef3 15. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x000000003a9c8ba7 16. ./build_docker/./src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x000000003a9cef80 17. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 18. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 19. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 2025.06.13 08:44:26.025934 [ 2141 ] {1466a6e8-ddc4-4cda-a89f-e1aca4296ec0} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 2.32 MiB (attempt to allocate chunk of 1.00 MiB bytes), maximum: 1.91 MiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59516) (comment: 00133_long_shard_memory_tracker_and_exception_safety.sh) (query 1, line 2) (in query: SELECT intDiv(number, 5) AS k, max(toString(number)) FROM remote('127.0.0.{2,3}', test_kuhweop8.numbers_100k) GROUP BY k ORDER BY k LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f53cbed 8. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f87f7ca 9. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fbc9cb5 10. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fbca326 11. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003a9b529c 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:21: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, unsigned long) @ 0x000000003a9b520b 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003a962bc6 14. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x000000003a97cef3 15. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x000000003a9c8ba7 16. ./build_docker/./src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x000000003a9cef80 17. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 18. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 19. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 2025.06.13 08:44:26.030262 [ 2141 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 2.32 MiB (attempt to allocate chunk of 1.00 MiB bytes), maximum: 1.91 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f53cbed 8. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f87f7ca 9. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fbc9cb5 10. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fbca326 11. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003a9b529c 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:21: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, unsigned long) @ 0x000000003a9b520b 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003a962bc6 14. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x000000003a97cef3 15. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x000000003a9c8ba7 16. ./build_docker/./src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x000000003a9cef80 17. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 18. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 19. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 2025.06.13 08:44:26.999720 [ 3255 ] {53012e0b-fe25-485f-92e5-b1ef5b71adc4} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:55956). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc8fc3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe68d 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:44:27.000943 [ 3255 ] {53012e0b-fe25-485f-92e5-b1ef5b71adc4} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:55956). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:55956) (comment: 00133_long_shard_memory_tracker_and_exception_safety.sh) (query 1, line 2) (in query: DESC TABLE test_kuhweop8.numbers_100k), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc8fc3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe68d 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:44:27.011570 [ 3255 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:55956). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc8fc3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe68d 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:44:27.063554 [ 2142 ] {62a3b6fc-92a8-4843-a6ab-0527b94b2068} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 3.32 MiB (attempt to allocate chunk of 1.00 MiB bytes), maximum: 2.38 MiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59542) (comment: 00133_long_shard_memory_tracker_and_exception_safety.sh) (query 1, line 2) (in query: SELECT intDiv(number, 5) AS k, max(toString(number)) FROM remote('127.0.0.{2,3}', test_kuhweop8.numbers_100k) GROUP BY k ORDER BY k LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./src/Common/FiberStack.h:65: FiberStack::allocate() const @ 0x000000002f23af12 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:312: boost::context::detail::fiber_activation_record* boost::context::detail::create_fiber1>(FiberStack&, Fiber::RoutineImpl&&) @ 0x000000002f23942a 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:449: DB::AsyncTaskExecutor::createFiber() @ 0x000000002f237e7d 10. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:19: DB::AsyncTaskExecutor::resume() @ 0x000000002f237b99 11. ./build_docker/./src/Client/HedgedConnections.cpp:410: DB::HedgedConnections::resumePacketReceiver(DB::HedgedConnections::ReplicaLocation const&) @ 0x000000003aa26aef 12. ./build_docker/./src/Client/HedgedConnections.cpp:389: DB::HedgedConnections::getReadyReplicaLocation(std::function) @ 0x000000003aa23dd3 13. ./build_docker/./src/Client/HedgedConnections.cpp:363: DB::HedgedConnections::receivePacketUnlocked(std::function) @ 0x000000003aa262eb 14. ./build_docker/./src/Client/HedgedConnections.cpp:345: DB::HedgedConnections::receivePacket() @ 0x000000003aa25d61 15. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:509: DB::RemoteQueryExecutor::read() @ 0x000000002f1d29f7 16. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:485: DB::RemoteQueryExecutor::readBlock() @ 0x000000002f1d1e60 17. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:100: DB::getStructureOfRemoteTableInShard(DB::Cluster const&, DB::Cluster::ShardInfo const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000038e26d27 18. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:160: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000038e2ac74 19. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:337: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002659d189 20. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:309: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002659b639 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d0326ad 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316edd5f 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030336f50 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 2025.06.13 08:44:27.068153 [ 2142 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 3.32 MiB (attempt to allocate chunk of 1.00 MiB bytes), maximum: 2.38 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./src/Common/FiberStack.h:65: FiberStack::allocate() const @ 0x000000002f23af12 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:312: boost::context::detail::fiber_activation_record* boost::context::detail::create_fiber1>(FiberStack&, Fiber::RoutineImpl&&) @ 0x000000002f23942a 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:449: DB::AsyncTaskExecutor::createFiber() @ 0x000000002f237e7d 10. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:19: DB::AsyncTaskExecutor::resume() @ 0x000000002f237b99 11. ./build_docker/./src/Client/HedgedConnections.cpp:410: DB::HedgedConnections::resumePacketReceiver(DB::HedgedConnections::ReplicaLocation const&) @ 0x000000003aa26aef 12. ./build_docker/./src/Client/HedgedConnections.cpp:389: DB::HedgedConnections::getReadyReplicaLocation(std::function) @ 0x000000003aa23dd3 13. ./build_docker/./src/Client/HedgedConnections.cpp:363: DB::HedgedConnections::receivePacketUnlocked(std::function) @ 0x000000003aa262eb 14. ./build_docker/./src/Client/HedgedConnections.cpp:345: DB::HedgedConnections::receivePacket() @ 0x000000003aa25d61 15. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:509: DB::RemoteQueryExecutor::read() @ 0x000000002f1d29f7 16. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:485: DB::RemoteQueryExecutor::readBlock() @ 0x000000002f1d1e60 17. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:100: DB::getStructureOfRemoteTableInShard(DB::Cluster const&, DB::Cluster::ShardInfo const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000038e26d27 18. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:160: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000038e2ac74 19. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:337: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002659d189 20. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:309: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002659b639 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d0326ad 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316edd5f 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030336f50 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 2025.06.13 08:44:27.329512 [ 2084 ] {94562293-e502-4822-9a15-30d3b79f655a} executeQuery: Code: 42. DB::Exception: Table name was not found in function arguments. Table function 'remote' requires from 1 to 6 parameters: [, , ] [, username[, password], sharding_key]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59554) (comment: 02841_remote_parameter_parsing_error.sql) (query 1, line 4) (in query: select * from remote('127.0.0.1', sys);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&&) @ 0x00000000265a1f4a 4. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:184: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000265990dc 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:44:27.332044 [ 2084 ] {} TCPHandler: Code: 42. DB::Exception: Table name was not found in function arguments. Table function 'remote' requires from 1 to 6 parameters: [, , ] [, username[, password], sharding_key]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&&) @ 0x00000000265a1f4a 4. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:184: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000265990dc 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:44:27.343088 [ 2084 ] {dd2f81be-2b7d-43a7-9d48-d8ff3097cd2b} executeQuery: Code: 42. DB::Exception: Table name was not found in function arguments. Table function 'remote' requires from 1 to 6 parameters: [, , ] [, username[, password], sharding_key]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59554) (comment: 02841_remote_parameter_parsing_error.sql) (query 2, line 5) (in query: select * from remote('127.0.0.1', system);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&&) @ 0x00000000265a1f4a 4. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:184: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000265990dc 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:44:27.344354 [ 2084 ] {} TCPHandler: Code: 42. DB::Exception: Table name was not found in function arguments. Table function 'remote' requires from 1 to 6 parameters: [, , ] [, username[, password], sharding_key]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&&) @ 0x00000000265a1f4a 4. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:184: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000265990dc 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:44:27.601699 [ 2084 ] {2c9ef5c0-ba24-46a7-b5a3-ff6657b3abdf} executeQuery: Code: 60. DB::Exception: Table system.o does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59554) (comment: 02841_remote_parameter_parsing_error.sql) (query 3, line 6) (in query: select * from remote('127.0.0.1', system.o);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8528 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:61: DB::getStructureOfRemoteTableInShard(DB::Cluster const&, DB::Cluster::ShardInfo const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000038e23a5b 8. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:150: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000038e2aa53 9. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:337: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002659d189 10. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:309: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002659b639 11. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d0326ad 12. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316edd5f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030336f50 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:44:27.603160 [ 2084 ] {} TCPHandler: Code: 60. DB::Exception: Table system.o does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8528 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:61: DB::getStructureOfRemoteTableInShard(DB::Cluster const&, DB::Cluster::ShardInfo const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000038e23a5b 8. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:150: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000038e2aa53 9. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:337: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002659d189 10. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:309: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002659b639 11. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d0326ad 12. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316edd5f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030336f50 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:44:27.647194 [ 2142 ] {96aa71c2-aa15-452c-ab94-773f4f95e333} executeQuery: Code: 59. DB::Exception: Illegal type Nullable(Int128) of column __table1.x for filter. Must be UInt8 or Nullable(UInt8). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59580) (comment: 02794_pushdown_invalid_get.sql) (query 1, line 1) (in query: SELECT * FROM (SELECT toInt128(NULL) AS x UNION ALL SELECT materialize(toInt128(-2))) WHERE x;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a1f836d 4. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:51: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003ba1825d 5. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003c039728 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000032a99dea 7. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032b178a2 8. ./build_docker/./src/Planner/Planner.cpp:1629: DB::Planner::buildPlanForQueryNode() @ 0x0000000032aff807 9. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:44:27.649633 [ 2142 ] {} TCPHandler: Code: 59. DB::Exception: Illegal type Nullable(Int128) of column __table1.x for filter. Must be UInt8 or Nullable(UInt8). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a1f836d 4. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:51: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003ba1825d 5. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003c039728 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000032a99dea 7. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032b178a2 8. ./build_docker/./src/Planner/Planner.cpp:1629: DB::Planner::buildPlanForQueryNode() @ 0x0000000032aff807 9. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:44:27.837095 [ 2084 ] {d65c0645-6fb0-460b-8669-ad906e6d2ea1} executeQuery: Code: 47. DB::Exception: Missing columns: 'default' while processing: 'default', required columns: 'default', available columns: 'dummy'. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59554) (comment: 02841_remote_parameter_parsing_error.sql) (query 4, line 7) (in query: select * from remote('127.0.0.1', system.one, default);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1303: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x0000000033504085 4. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1561: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003352681b 5. ./build_docker/./src/Storages/StorageDistributed.cpp:265: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x0000000038354722 6. ./build_docker/./src/Storages/StorageDistributed.cpp:408: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr, bool) @ 0x000000003834ed73 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, String const&, String const&, String, std::shared_ptr&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, std::shared_ptr const&, bool, 0>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, String const&, String const&, String&&, std::shared_ptr&, std::shared_ptr const&, String&&, String&&, DB::DistributedSettings&&, DB::LoadingStrictnessLevel&&, std::shared_ptr const&, std::shared_ptr const&, bool&&) @ 0x00000000265aa6c0 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002659c074 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d0326ad 10. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316edd5f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030336f50 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:44:27.839095 [ 2084 ] {} TCPHandler: Code: 47. DB::Exception: Missing columns: 'default' while processing: 'default', required columns: 'default', available columns: 'dummy'. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1303: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x0000000033504085 4. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1561: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003352681b 5. ./build_docker/./src/Storages/StorageDistributed.cpp:265: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x0000000038354722 6. ./build_docker/./src/Storages/StorageDistributed.cpp:408: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr, bool) @ 0x000000003834ed73 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, String const&, String const&, String, std::shared_ptr&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, std::shared_ptr const&, bool, 0>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, String const&, String const&, String&&, std::shared_ptr&, std::shared_ptr const&, String&&, String&&, DB::DistributedSettings&&, DB::LoadingStrictnessLevel&&, std::shared_ptr const&, std::shared_ptr const&, bool&&) @ 0x00000000265aa6c0 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002659c074 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d0326ad 10. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316edd5f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030336f50 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:44:27.919053 [ 2136 ] {01d1ce88-ece0-4307-b06b-36ba2e0e8059} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 3.32 MiB (attempt to allocate chunk of 1.00 MiB bytes), maximum: 2.86 MiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59590) (comment: 00133_long_shard_memory_tracker_and_exception_safety.sh) (query 1, line 2) (in query: SELECT intDiv(number, 5) AS k, max(toString(number)) FROM remote('127.0.0.{2,3}', test_kuhweop8.numbers_100k) GROUP BY k ORDER BY k LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./src/Common/FiberStack.h:65: FiberStack::allocate() const @ 0x000000002f23af12 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:312: boost::context::detail::fiber_activation_record* boost::context::detail::create_fiber1>(FiberStack&, Fiber::RoutineImpl&&) @ 0x000000002f23942a 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:449: DB::AsyncTaskExecutor::createFiber() @ 0x000000002f237e7d 10. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:19: DB::AsyncTaskExecutor::resume() @ 0x000000002f237b99 11. ./build_docker/./src/Client/HedgedConnections.cpp:410: DB::HedgedConnections::resumePacketReceiver(DB::HedgedConnections::ReplicaLocation const&) @ 0x000000003aa26aef 12. ./build_docker/./src/Client/HedgedConnections.cpp:389: DB::HedgedConnections::getReadyReplicaLocation(std::function) @ 0x000000003aa23dd3 13. ./build_docker/./src/Client/HedgedConnections.cpp:363: DB::HedgedConnections::receivePacketUnlocked(std::function) @ 0x000000003aa262eb 14. ./build_docker/./src/Client/HedgedConnections.cpp:345: DB::HedgedConnections::receivePacket() @ 0x000000003aa25d61 15. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:509: DB::RemoteQueryExecutor::read() @ 0x000000002f1d29f7 16. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:485: DB::RemoteQueryExecutor::readBlock() @ 0x000000002f1d1e60 17. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:100: DB::getStructureOfRemoteTableInShard(DB::Cluster const&, DB::Cluster::ShardInfo const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000038e26d27 18. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:160: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000038e2ac74 19. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:337: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002659d189 20. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:309: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002659b639 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d0326ad 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316edd5f 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030336f50 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 2025.06.13 08:44:27.929976 [ 2136 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 3.32 MiB (attempt to allocate chunk of 1.00 MiB bytes), maximum: 2.86 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./src/Common/FiberStack.h:65: FiberStack::allocate() const @ 0x000000002f23af12 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:312: boost::context::detail::fiber_activation_record* boost::context::detail::create_fiber1>(FiberStack&, Fiber::RoutineImpl&&) @ 0x000000002f23942a 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:449: DB::AsyncTaskExecutor::createFiber() @ 0x000000002f237e7d 10. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:19: DB::AsyncTaskExecutor::resume() @ 0x000000002f237b99 11. ./build_docker/./src/Client/HedgedConnections.cpp:410: DB::HedgedConnections::resumePacketReceiver(DB::HedgedConnections::ReplicaLocation const&) @ 0x000000003aa26aef 12. ./build_docker/./src/Client/HedgedConnections.cpp:389: DB::HedgedConnections::getReadyReplicaLocation(std::function) @ 0x000000003aa23dd3 13. ./build_docker/./src/Client/HedgedConnections.cpp:363: DB::HedgedConnections::receivePacketUnlocked(std::function) @ 0x000000003aa262eb 14. ./build_docker/./src/Client/HedgedConnections.cpp:345: DB::HedgedConnections::receivePacket() @ 0x000000003aa25d61 15. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:509: DB::RemoteQueryExecutor::read() @ 0x000000002f1d29f7 16. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:485: DB::RemoteQueryExecutor::readBlock() @ 0x000000002f1d1e60 17. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:100: DB::getStructureOfRemoteTableInShard(DB::Cluster const&, DB::Cluster::ShardInfo const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000038e26d27 18. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:160: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000038e2ac74 19. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:337: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002659d189 20. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:309: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002659b639 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d0326ad 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316edd5f 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030336f50 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 2025.06.13 08:44:28.011943 [ 404 ] {d3ec8a3f-bfe0-49e1-8516-c98e489760b7} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:55970). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:55970) (comment: 00133_long_shard_memory_tracker_and_exception_safety.sh) (query 1, line 2) (in query: DESC TABLE test_kuhweop8.numbers_100k), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc8fc3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:1421: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe992 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:44:28.023936 [ 404 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:55970). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc8fc3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:1421: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe992 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:44:28.087176 [ 2084 ] {3b6411c3-d8ae-48e5-a8a4-ea2501fd0d5d} executeQuery: Code: 36. DB::Exception: Arguments `user` and `password` should be string literals (in single quotes). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59554) (comment: 02841_remote_parameter_parsing_error.sql) (query 5, line 8) (in query: SELECT * FROM remote('127.0.0.1', system.one, default, '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:230: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000026598859 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:44:28.089037 [ 2084 ] {} TCPHandler: Code: 36. DB::Exception: Arguments `user` and `password` should be string literals (in single quotes). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:230: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000026598859 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:44:28.103795 [ 2084 ] {b1732588-7a02-4253-948a-d2ec8d5f2c44} executeQuery: Code: 36. DB::Exception: Arguments `user` and `password` should be string literals (in single quotes). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59554) (comment: 02841_remote_parameter_parsing_error.sql) (query 6, line 9) (in query: select * from remote('127.0.0.1', system.one, default, key1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:230: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000026598859 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:44:28.105779 [ 2084 ] {} TCPHandler: Code: 36. DB::Exception: Arguments `user` and `password` should be string literals (in single quotes). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:230: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000026598859 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:44:28.134852 [ 2084 ] {9167cb6a-1a44-4aae-b3d4-eba55804678e} executeQuery: Code: 47. DB::Exception: Missing columns: 'key1' while processing: 'key1', required columns: 'key1', available columns: 'dummy'. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59554) (comment: 02841_remote_parameter_parsing_error.sql) (query 7, line 10) (in query: SELECT * FROM remote('127.0.0.1', system.one, 'default', '[HIDDEN]', key1)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1303: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x0000000033504085 4. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1561: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003352681b 5. ./build_docker/./src/Storages/StorageDistributed.cpp:265: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x0000000038354722 6. ./build_docker/./src/Storages/StorageDistributed.cpp:408: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr, bool) @ 0x000000003834ed73 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, String const&, String const&, String, std::shared_ptr&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, std::shared_ptr const&, bool, 0>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, String const&, String const&, String&&, std::shared_ptr&, std::shared_ptr const&, String&&, String&&, DB::DistributedSettings&&, DB::LoadingStrictnessLevel&&, std::shared_ptr const&, std::shared_ptr const&, bool&&) @ 0x00000000265aa6c0 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002659c074 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d0326ad 10. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316edd5f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030336f50 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:44:28.136953 [ 2084 ] {} TCPHandler: Code: 47. DB::Exception: Missing columns: 'key1' while processing: 'key1', required columns: 'key1', available columns: 'dummy'. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1303: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x0000000033504085 4. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1561: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003352681b 5. ./build_docker/./src/Storages/StorageDistributed.cpp:265: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x0000000038354722 6. ./build_docker/./src/Storages/StorageDistributed.cpp:408: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr, bool) @ 0x000000003834ed73 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, String const&, String const&, String, std::shared_ptr&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, std::shared_ptr const&, bool, 0>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, String const&, String const&, String&&, std::shared_ptr&, std::shared_ptr const&, String&&, String&&, DB::DistributedSettings&&, DB::LoadingStrictnessLevel&&, std::shared_ptr const&, std::shared_ptr const&, bool&&) @ 0x00000000265aa6c0 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002659c074 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d0326ad 10. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316edd5f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030336f50 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:44:28.151192 [ 2084 ] {2a1332ec-607d-4a49-8da6-b0fedd629f19} executeQuery: Code: 36. DB::Exception: Arguments `user` and `password` should be string literals (in single quotes). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59554) (comment: 02841_remote_parameter_parsing_error.sql) (query 8, line 11) (in query: SELECT * FROM remote('127.0.0.1', system.one, default, '[HIDDEN]', key1)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:230: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000026598859 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:44:28.153700 [ 2084 ] {} TCPHandler: Code: 36. DB::Exception: Arguments `user` and `password` should be string literals (in single quotes). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:230: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000026598859 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:44:28.170500 [ 2084 ] {27d3d4c8-2cce-4a97-b3b5-d38b3aa74e92} executeQuery: Code: 36. DB::Exception: Arguments `user` and `password` should be string literals (in single quotes). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59554) (comment: 02841_remote_parameter_parsing_error.sql) (query 9, line 12) (in query: select * from remote('127.0.0.1', system.one, 'default', pwd, key1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:230: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000026598859 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:44:28.172644 [ 2084 ] {} TCPHandler: Code: 36. DB::Exception: Arguments `user` and `password` should be string literals (in single quotes). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:230: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000026598859 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:44:28.369323 [ 2084 ] {a2c53db2-3657-4739-9a12-49f8f6dd1e46} executeQuery: Code: 42. DB::Exception: Table function 'remote' requires from 1 to 6 parameters: [, , ] [, username[, password], sharding_key]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59554) (comment: 02841_remote_parameter_parsing_error.sql) (query 10, line 13) (in query: SELECT * FROM remote('127.0.0.1', system.one, 'default', '[HIDDEN]', key1, key2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x000000002659f49f 3. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:238: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000026597e1f 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:44:28.373500 [ 2084 ] {} TCPHandler: Code: 42. DB::Exception: Table function 'remote' requires from 1 to 6 parameters: [, , ] [, username[, password], sharding_key]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x000000002659f49f 3. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:238: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000026597e1f 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:44:28.548419 [ 2084 ] {3034c0e7-4dbb-444a-b787-f04c3b1e3016} executeQuery: Code: 42. DB::Exception: Table function 'remote' requires from 1 to 6 parameters: [, , ] [, username[, password], sharding_key]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59554) (comment: 02841_remote_parameter_parsing_error.sql) (query 11, line 14) (in query: SELECT * FROM remote('127.0.0.1', system, one, 'default', '[HIDDEN]', key1, key2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x000000002659f49f 3. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:124: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000026597da1 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:44:28.550571 [ 2084 ] {} TCPHandler: Code: 42. DB::Exception: Table function 'remote' requires from 1 to 6 parameters: [, , ] [, username[, password], sharding_key]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x000000002659f49f 3. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:124: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000026597da1 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:44:28.971721 [ 2133 ] {b356a4b2-d9c7-4041-b14f-1a9138ad98c3} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 5.26 MiB (attempt to allocate chunk of 1.94 MiB bytes), maximum: 3.34 MiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59632) (comment: 00133_long_shard_memory_tracker_and_exception_safety.sh) (query 1, line 2) (in query: SELECT intDiv(number, 5) AS k, max(toString(number)) FROM remote('127.0.0.{2,3}', test_kuhweop8.numbers_100k) GROUP BY k ORDER BY k LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f53cbed 8. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f87f7ca 9. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fbc3f59 10. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fbc4526 11. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003a9af552 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:15: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, unsigned long) @ 0x000000003a9af4cb 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003a9625d1 14. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x000000003a97cef3 15. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x000000003a9c8ba7 16. ./build_docker/./src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x000000003a9cef80 17. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 18. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 19. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 2025.06.13 08:44:29.125676 [ 2133 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 5.26 MiB (attempt to allocate chunk of 1.94 MiB bytes), maximum: 3.34 MiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f53cbed 8. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f87f7ca 9. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fbc3f59 10. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fbc4526 11. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003a9af552 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:15: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, unsigned long) @ 0x000000003a9af4cb 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003a9625d1 14. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x000000003a97cef3 15. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x000000003a9c8ba7 16. ./build_docker/./src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x000000003a9cef80 17. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 18. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 19. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:44:29.261298 [ 3255 ] {a25277e3-e872-4319-9de6-fb8eca49043e} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 3.76 MiB (attempt to allocate chunk of 1.25 MiB bytes), maximum: 3.34 MiB.: while executing 'FUNCTION toString(__table1.number :: 2) -> toString(__table1.number) String : 1'. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:55976) (comment: 00133_long_shard_memory_tracker_and_exception_safety.sh) (query 1, line 2) (in query: SELECT intDiv(`__table1`.`number`, 5) AS `k`, max(toString(`__table1`.`number`)) AS `max(toString(number))` FROM `test_kuhweop8`.`numbers_100k` AS `__table1` GROUP BY intDiv(`__table1`.`number`, 5) ORDER BY intDiv(`__table1`.`number`, 5) ASC LIMIT _CAST(1, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f53cbed 8. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008ba58bc 9. ./src/Functions/FunctionsConversion.h:1533: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cc966ba 10. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeString>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cc8c779 11. ./src/Core/callOnTypeIndex.h:255: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c84dfbb 12. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c84c842 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:44:29.378614 [ 3255 ] {a25277e3-e872-4319-9de6-fb8eca49043e} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:55976). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2557: DB::TCPHandler::sendException(DB::Exception const&, bool) @ 0x000000003adb5f67 7. ./build_docker/./src/Server/TCPHandler.cpp:825: DB::TCPHandler::runImpl() @ 0x000000003ad8f542 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:44:29.381277 [ 3255 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 3.76 MiB (attempt to allocate chunk of 1.25 MiB bytes), maximum: 3.34 MiB.: while executing 'FUNCTION toString(__table1.number :: 2) -> toString(__table1.number) String : 1'. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f53cbed 8. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008ba58bc 9. ./src/Functions/FunctionsConversion.h:1533: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cc966ba 10. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeString>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cc8c779 11. ./src/Core/callOnTypeIndex.h:255: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c84dfbb 12. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c84c842 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:44:30.810253 [ 2133 ] {4671bb52-90af-4109-afec-7bbee31e9dc6} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 4.57 MiB (attempt to allocate chunk of 1.25 MiB bytes), maximum: 3.81 MiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59690) (comment: 00133_long_shard_memory_tracker_and_exception_safety.sh) (query 1, line 2) (in query: SELECT intDiv(number, 5) AS k, max(toString(number)) FROM remote('127.0.0.{2,3}', test_kuhweop8.numbers_100k) GROUP BY k ORDER BY k LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./src/Common/FiberStack.h:65: FiberStack::allocate() const @ 0x000000002f23af12 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:312: boost::context::detail::fiber_activation_record* boost::context::detail::create_fiber1>(FiberStack&, Fiber::RoutineImpl&&) @ 0x000000002f23942a 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:449: DB::AsyncTaskExecutor::createFiber() @ 0x000000002f237e7d 10. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:19: DB::AsyncTaskExecutor::resume() @ 0x000000002f237b99 11. ./src/Client/ConnectionEstablisher.h:79: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000003aa3c140 12. ./build_docker/./src/Client/HedgedConnections.cpp:67: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000003aa19828 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002f204e76 14. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002f1e75e7 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f1cc5c0 16. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f23f0fe 17. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 18. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 19. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 2025.06.13 08:44:30.900683 [ 2133 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 4.57 MiB (attempt to allocate chunk of 1.25 MiB bytes), maximum: 3.81 MiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./src/Common/FiberStack.h:65: FiberStack::allocate() const @ 0x000000002f23af12 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:312: boost::context::detail::fiber_activation_record* boost::context::detail::create_fiber1>(FiberStack&, Fiber::RoutineImpl&&) @ 0x000000002f23942a 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:449: DB::AsyncTaskExecutor::createFiber() @ 0x000000002f237e7d 10. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:19: DB::AsyncTaskExecutor::resume() @ 0x000000002f237b99 11. ./src/Client/ConnectionEstablisher.h:79: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000003aa3c140 12. ./build_docker/./src/Client/HedgedConnections.cpp:67: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000003aa19828 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002f204e76 14. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002f1e75e7 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f1cc5c0 16. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f23f0fe 17. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 18. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 19. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:44:31.152271 [ 3255 ] {b093a24f-9eb0-485c-b353-2053cc978aa3} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:55990). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc8fc3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2569: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000003adc01f6 7. ./build_docker/./src/Server/TCPHandler.cpp:823: DB::TCPHandler::runImpl() @ 0x000000003ad8f4fc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:44:32.237577 [ 404 ] {34680006-afd2-4a09-a3e5-406d7a22d790} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 4.57 MiB (attempt to allocate chunk of 1.25 MiB bytes), maximum: 4.29 MiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59712) (comment: 00133_long_shard_memory_tracker_and_exception_safety.sh) (query 1, line 2) (in query: SELECT intDiv(number, 5) AS k, max(toString(number)) FROM remote('127.0.0.{2,3}', test_kuhweop8.numbers_100k) GROUP BY k ORDER BY k LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./src/Common/FiberStack.h:65: FiberStack::allocate() const @ 0x000000002f23af12 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:312: boost::context::detail::fiber_activation_record* boost::context::detail::create_fiber1>(FiberStack&, Fiber::RoutineImpl&&) @ 0x000000002f23942a 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:449: DB::AsyncTaskExecutor::createFiber() @ 0x000000002f237e7d 10. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:19: DB::AsyncTaskExecutor::resume() @ 0x000000002f237b99 11. ./src/Client/ConnectionEstablisher.h:79: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000003aa3c140 12. ./build_docker/./src/Client/HedgedConnections.cpp:67: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000003aa19828 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002f204e76 14. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002f1e75e7 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f1cc5c0 16. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f23f0fe 17. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 18. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 19. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 2025.06.13 08:44:32.263627 [ 404 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 4.57 MiB (attempt to allocate chunk of 1.25 MiB bytes), maximum: 4.29 MiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./src/Common/FiberStack.h:65: FiberStack::allocate() const @ 0x000000002f23af12 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:312: boost::context::detail::fiber_activation_record* boost::context::detail::create_fiber1>(FiberStack&, Fiber::RoutineImpl&&) @ 0x000000002f23942a 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:449: DB::AsyncTaskExecutor::createFiber() @ 0x000000002f237e7d 10. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:19: DB::AsyncTaskExecutor::resume() @ 0x000000002f237b99 11. ./src/Client/ConnectionEstablisher.h:79: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000003aa3c140 12. ./build_docker/./src/Client/HedgedConnections.cpp:67: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000003aa19828 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002f204e76 14. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002f1e75e7 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f1cc5c0 16. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f23f0fe 17. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 18. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 19. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:44:32.945851 [ 2134 ] {2f7ac2f7-2a43-41e1-b25c-8bc4a8d23304} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 5.75 MiB (attempt to allocate chunk of 1.99 MiB bytes), maximum: 4.29 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:55998) (comment: 00133_long_shard_memory_tracker_and_exception_safety.sh) (query 1, line 2) (in query: SELECT intDiv(`__table1`.`number`, 5) AS `k`, max(toString(`__table1`.`number`)) AS `max(toString(number))` FROM `test_kuhweop8`.`numbers_100k` AS `__table1` GROUP BY intDiv(`__table1`.`number`, 5) ORDER BY intDiv(`__table1`.`number`, 5) ASC LIMIT _CAST(1, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f53f624 8. ./src/Common/HashTable/HashTable.h:538: HashTable, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>::resize(unsigned long, unsigned long) @ 0x0000000031f3a0ad 9. ./src/Common/HashTable/HashTable.h:926: void DB::Aggregator::executeImplBatch, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x000000003205fb8c 10. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000003205bbcd 11. ./build_docker/./src/Interpreters/Aggregator.cpp:946: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x0000000031daed6f 12. ./build_docker/./src/Interpreters/Aggregator.cpp:922: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x0000000031bc55bb 13. ./build_docker/./src/Interpreters/Aggregator.cpp:1587: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031bd0b95 14. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003b9b97c5 15. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003b9ac388 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:44:33.066985 [ 2134 ] {2f7ac2f7-2a43-41e1-b25c-8bc4a8d23304} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:55998). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2531: DB::TCPHandler::sendLogData(DB::QueryState&, DB::Block const&) @ 0x000000003adf5ea1 7. ./build_docker/./src/Server/TCPHandler.cpp:2619: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x000000003adbfa58 8. ./build_docker/./src/Server/TCPHandler.cpp:820: DB::TCPHandler::runImpl() @ 0x000000003ad8f4a9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:44:33.069130 [ 2134 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 5.75 MiB (attempt to allocate chunk of 1.99 MiB bytes), maximum: 4.29 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f53f624 8. ./src/Common/HashTable/HashTable.h:538: HashTable, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>::resize(unsigned long, unsigned long) @ 0x0000000031f3a0ad 9. ./src/Common/HashTable/HashTable.h:926: void DB::Aggregator::executeImplBatch, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x000000003205fb8c 10. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000003205bbcd 11. ./build_docker/./src/Interpreters/Aggregator.cpp:946: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x0000000031daed6f 12. ./build_docker/./src/Interpreters/Aggregator.cpp:922: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x0000000031bc55bb 13. ./build_docker/./src/Interpreters/Aggregator.cpp:1587: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031bd0b95 14. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003b9b97c5 15. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003b9ac388 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:44:33.231413 [ 404 ] {a13f1fee-de1d-4df0-b6bc-500e4770000e} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 5.57 MiB (attempt to allocate chunk of 1.00 MiB bytes), maximum: 4.77 MiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34292) (comment: 00133_long_shard_memory_tracker_and_exception_safety.sh) (query 1, line 2) (in query: SELECT intDiv(number, 5) AS k, max(toString(number)) FROM remote('127.0.0.{2,3}', test_kuhweop8.numbers_100k) GROUP BY k ORDER BY k LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f53cbed 8. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f87f7ca 9. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fbc3f59 10. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fbc4526 11. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003a9af552 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:15: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, unsigned long) @ 0x000000003a9af4cb 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003a9625d1 14. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x000000003a97cef3 15. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x000000003a9c8ba7 16. ./build_docker/./src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x000000003a9cef80 17. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 18. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 19. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 2025.06.13 08:44:33.245117 [ 404 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 5.57 MiB (attempt to allocate chunk of 1.00 MiB bytes), maximum: 4.77 MiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f53cbed 8. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f87f7ca 9. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fbc3f59 10. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fbc4526 11. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003a9af552 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:15: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, unsigned long) @ 0x000000003a9af4cb 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003a9625d1 14. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x000000003a97cef3 15. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x000000003a9c8ba7 16. ./build_docker/./src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x000000003a9cef80 17. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 18. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 19. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:44:33.342928 [ 2134 ] {9ea06b63-4e78-4094-a539-2ec5e5b0177d} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 5.75 MiB (attempt to allocate chunk of 1.99 MiB bytes), maximum: 4.77 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:34800) (comment: 00133_long_shard_memory_tracker_and_exception_safety.sh) (query 1, line 2) (in query: SELECT intDiv(`__table1`.`number`, 5) AS `k`, max(toString(`__table1`.`number`)) AS `max(toString(number))` FROM `test_kuhweop8`.`numbers_100k` AS `__table1` GROUP BY intDiv(`__table1`.`number`, 5) ORDER BY intDiv(`__table1`.`number`, 5) ASC LIMIT _CAST(1, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f53f624 8. ./src/Common/HashTable/HashTable.h:538: HashTable, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>::resize(unsigned long, unsigned long) @ 0x0000000031f3a0ad 9. ./src/Common/HashTable/HashTable.h:926: void DB::Aggregator::executeImplBatch, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x000000003205fb8c 10. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000003205bbcd 11. ./build_docker/./src/Interpreters/Aggregator.cpp:946: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x0000000031daed6f 12. ./build_docker/./src/Interpreters/Aggregator.cpp:922: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x0000000031bc55bb 13. ./build_docker/./src/Interpreters/Aggregator.cpp:1587: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031bd0b95 14. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003b9b97c5 15. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003b9ac388 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:44:33.350164 [ 2134 ] {9ea06b63-4e78-4094-a539-2ec5e5b0177d} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:34800). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2531: DB::TCPHandler::sendLogData(DB::QueryState&, DB::Block const&) @ 0x000000003adf5ea1 7. ./build_docker/./src/Server/TCPHandler.cpp:2619: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x000000003adbfa58 8. ./build_docker/./src/Server/TCPHandler.cpp:820: DB::TCPHandler::runImpl() @ 0x000000003ad8f4a9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:44:33.352997 [ 2134 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 5.75 MiB (attempt to allocate chunk of 1.99 MiB bytes), maximum: 4.77 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f53f624 8. ./src/Common/HashTable/HashTable.h:538: HashTable, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>::resize(unsigned long, unsigned long) @ 0x0000000031f3a0ad 9. ./src/Common/HashTable/HashTable.h:926: void DB::Aggregator::executeImplBatch, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x000000003205fb8c 10. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000003205bbcd 11. ./build_docker/./src/Interpreters/Aggregator.cpp:946: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x0000000031daed6f 12. ./build_docker/./src/Interpreters/Aggregator.cpp:922: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x0000000031bc55bb 13. ./build_docker/./src/Interpreters/Aggregator.cpp:1587: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031bd0b95 14. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003b9b97c5 15. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003b9ac388 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:44:34.394792 [ 2134 ] {e6180997-db86-434d-90b5-c3f5684323a8} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 5.57 MiB (attempt to allocate chunk of 1.00 MiB bytes), maximum: 5.25 MiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34324) (comment: 00133_long_shard_memory_tracker_and_exception_safety.sh) (query 1, line 2) (in query: SELECT intDiv(number, 5) AS k, max(toString(number)) FROM remote('127.0.0.{2,3}', test_kuhweop8.numbers_100k) GROUP BY k ORDER BY k LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f53cbed 8. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f87f7ca 9. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fbc3f59 10. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fbc4526 11. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003a9af552 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:15: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, unsigned long) @ 0x000000003a9af4cb 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003a9625d1 14. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x000000003a97cef3 15. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x000000003a9c8ba7 16. ./build_docker/./src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x000000003a9cef80 17. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 18. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 19. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 2025.06.13 08:44:34.406671 [ 2134 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 5.57 MiB (attempt to allocate chunk of 1.00 MiB bytes), maximum: 5.25 MiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f53cbed 8. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f87f7ca 9. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fbc3f59 10. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fbc4526 11. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003a9af552 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:15: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, unsigned long) @ 0x000000003a9af4cb 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003a9625d1 14. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x000000003a97cef3 15. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x000000003a9c8ba7 16. ./build_docker/./src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x000000003a9cef80 17. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 18. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 19. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:44:34.472173 [ 2133 ] {172ea8e6-0fe8-40fb-b7ff-7aaf237c1c29} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 5.75 MiB (attempt to allocate chunk of 1.99 MiB bytes), maximum: 5.25 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:34814) (comment: 00133_long_shard_memory_tracker_and_exception_safety.sh) (query 1, line 2) (in query: SELECT intDiv(`__table1`.`number`, 5) AS `k`, max(toString(`__table1`.`number`)) AS `max(toString(number))` FROM `test_kuhweop8`.`numbers_100k` AS `__table1` GROUP BY intDiv(`__table1`.`number`, 5) ORDER BY intDiv(`__table1`.`number`, 5) ASC LIMIT _CAST(1, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f53f624 8. ./src/Common/HashTable/HashTable.h:538: HashTable, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>::resize(unsigned long, unsigned long) @ 0x0000000031f3a0ad 9. ./src/Common/HashTable/HashTable.h:926: void DB::Aggregator::executeImplBatch, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x000000003205fb8c 10. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000003205bbcd 11. ./build_docker/./src/Interpreters/Aggregator.cpp:946: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x0000000031daed6f 12. ./build_docker/./src/Interpreters/Aggregator.cpp:922: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x0000000031bc55bb 13. ./build_docker/./src/Interpreters/Aggregator.cpp:1587: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031bd0b95 14. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003b9b97c5 15. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003b9ac388 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:44:34.484637 [ 2133 ] {172ea8e6-0fe8-40fb-b7ff-7aaf237c1c29} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:34814). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2531: DB::TCPHandler::sendLogData(DB::QueryState&, DB::Block const&) @ 0x000000003adf5ea1 7. ./build_docker/./src/Server/TCPHandler.cpp:2619: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x000000003adbfa58 8. ./build_docker/./src/Server/TCPHandler.cpp:820: DB::TCPHandler::runImpl() @ 0x000000003ad8f4a9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:44:34.500750 [ 2133 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 5.75 MiB (attempt to allocate chunk of 1.99 MiB bytes), maximum: 5.25 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f53f624 8. ./src/Common/HashTable/HashTable.h:538: HashTable, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>::resize(unsigned long, unsigned long) @ 0x0000000031f3a0ad 9. ./src/Common/HashTable/HashTable.h:926: void DB::Aggregator::executeImplBatch, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x000000003205fb8c 10. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000003205bbcd 11. ./build_docker/./src/Interpreters/Aggregator.cpp:946: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x0000000031daed6f 12. ./build_docker/./src/Interpreters/Aggregator.cpp:922: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x0000000031bc55bb 13. ./build_docker/./src/Interpreters/Aggregator.cpp:1587: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031bd0b95 14. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003b9b97c5 15. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003b9ac388 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:44:35.409721 [ 2141 ] {b68241a1-2d51-4338-bf43-17c8025642b6} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 6.57 MiB (attempt to allocate chunk of 1.00 MiB bytes), maximum: 5.72 MiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34338) (comment: 00133_long_shard_memory_tracker_and_exception_safety.sh) (query 1, line 2) (in query: SELECT intDiv(number, 5) AS k, max(toString(number)) FROM remote('127.0.0.{2,3}', test_kuhweop8.numbers_100k) GROUP BY k ORDER BY k LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f53cbed 8. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f87f7ca 9. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fbc9cb5 10. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fbca326 11. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003a9b529c 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:21: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, unsigned long) @ 0x000000003a9b520b 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003a962bc6 14. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x000000003a97cef3 15. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x000000003a9c8ba7 16. ./build_docker/./src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x000000003a9cef80 17. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 18. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 19. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 2025.06.13 08:44:35.416998 [ 2141 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 6.57 MiB (attempt to allocate chunk of 1.00 MiB bytes), maximum: 5.72 MiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f53cbed 8. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f87f7ca 9. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fbc9cb5 10. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fbca326 11. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003a9b529c 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:21: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, unsigned long) @ 0x000000003a9b520b 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003a962bc6 14. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x000000003a97cef3 15. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x000000003a9c8ba7 16. ./build_docker/./src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x000000003a9cef80 17. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 18. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 19. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:44:35.496036 [ 2133 ] {8671096a-9a47-4652-bc44-44824f821fa7} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 5.75 MiB (attempt to allocate chunk of 1.99 MiB bytes), maximum: 5.72 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:34836) (comment: 00133_long_shard_memory_tracker_and_exception_safety.sh) (query 1, line 2) (in query: SELECT intDiv(`__table1`.`number`, 5) AS `k`, max(toString(`__table1`.`number`)) AS `max(toString(number))` FROM `test_kuhweop8`.`numbers_100k` AS `__table1` GROUP BY intDiv(`__table1`.`number`, 5) ORDER BY intDiv(`__table1`.`number`, 5) ASC LIMIT _CAST(1, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f53f624 8. ./src/Common/HashTable/HashTable.h:538: HashTable, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>::resize(unsigned long, unsigned long) @ 0x0000000031f3a0ad 9. ./src/Common/HashTable/HashTable.h:926: void DB::Aggregator::executeImplBatch, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x000000003205fb8c 10. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000003205bbcd 11. ./build_docker/./src/Interpreters/Aggregator.cpp:946: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x0000000031daed6f 12. ./build_docker/./src/Interpreters/Aggregator.cpp:922: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x0000000031bc55bb 13. ./build_docker/./src/Interpreters/Aggregator.cpp:1587: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031bd0b95 14. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003b9b97c5 15. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003b9ac388 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:44:35.510352 [ 2133 ] {8671096a-9a47-4652-bc44-44824f821fa7} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:34836). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2531: DB::TCPHandler::sendLogData(DB::QueryState&, DB::Block const&) @ 0x000000003adf5ea1 7. ./build_docker/./src/Server/TCPHandler.cpp:2619: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x000000003adbfa58 8. ./build_docker/./src/Server/TCPHandler.cpp:820: DB::TCPHandler::runImpl() @ 0x000000003ad8f4a9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:44:35.512842 [ 2133 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 5.75 MiB (attempt to allocate chunk of 1.99 MiB bytes), maximum: 5.72 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f53f624 8. ./src/Common/HashTable/HashTable.h:538: HashTable, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>::resize(unsigned long, unsigned long) @ 0x0000000031f3a0ad 9. ./src/Common/HashTable/HashTable.h:926: void DB::Aggregator::executeImplBatch, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x000000003205fb8c 10. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000003205bbcd 11. ./build_docker/./src/Interpreters/Aggregator.cpp:946: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x0000000031daed6f 12. ./build_docker/./src/Interpreters/Aggregator.cpp:922: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x0000000031bc55bb 13. ./build_docker/./src/Interpreters/Aggregator.cpp:1587: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031bd0b95 14. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003b9b97c5 15. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003b9ac388 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:44:36.423053 [ 2133 ] {59aeee07-0c2a-4ae5-ae2c-226665acc41a} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 6.57 MiB (attempt to allocate chunk of 1.00 MiB bytes), maximum: 6.20 MiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34364) (comment: 00133_long_shard_memory_tracker_and_exception_safety.sh) (query 1, line 2) (in query: SELECT intDiv(number, 5) AS k, max(toString(number)) FROM remote('127.0.0.{2,3}', test_kuhweop8.numbers_100k) GROUP BY k ORDER BY k LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f53cbed 8. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f87f7ca 9. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fbc9cb5 10. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fbca326 11. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003a9b529c 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:21: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, unsigned long) @ 0x000000003a9b520b 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003a962bc6 14. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x000000003a97cef3 15. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x000000003a9c8ba7 16. ./build_docker/./src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x000000003a9cef80 17. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 18. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 19. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 2025.06.13 08:44:36.442927 [ 2133 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 6.57 MiB (attempt to allocate chunk of 1.00 MiB bytes), maximum: 6.20 MiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f53cbed 8. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f87f7ca 9. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fbc9cb5 10. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fbca326 11. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003a9b529c 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:21: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, unsigned long) @ 0x000000003a9b520b 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003a962bc6 14. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x000000003a97cef3 15. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x000000003a9c8ba7 16. ./build_docker/./src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x000000003a9cef80 17. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 18. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 19. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:44:36.705156 [ 2136 ] {00404eb2-81bf-4968-a959-b31fd6172174} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:34844). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2569: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000003adc01f6 7. ./build_docker/./src/Server/TCPHandler.cpp:823: DB::TCPHandler::runImpl() @ 0x000000003ad8f4fc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:44:37.653262 [ 3514 ] {ed6645c6-ac44-4334-8640-cf614393a6b5} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 7.26 MiB (attempt to allocate chunk of 1.00 MiB bytes), maximum: 6.68 MiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34394) (comment: 00133_long_shard_memory_tracker_and_exception_safety.sh) (query 1, line 2) (in query: SELECT intDiv(number, 5) AS k, max(toString(number)) FROM remote('127.0.0.{2,3}', test_kuhweop8.numbers_100k) GROUP BY k ORDER BY k LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./src/Common/FiberStack.h:65: FiberStack::allocate() const @ 0x000000002f23af12 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:312: boost::context::detail::fiber_activation_record* boost::context::detail::create_fiber1>(FiberStack&, Fiber::RoutineImpl&&) @ 0x000000002f23942a 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:449: DB::AsyncTaskExecutor::createFiber() @ 0x000000002f237e7d 10. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:19: DB::AsyncTaskExecutor::resume() @ 0x000000002f237b99 11. ./build_docker/./src/Client/HedgedConnections.cpp:410: DB::HedgedConnections::resumePacketReceiver(DB::HedgedConnections::ReplicaLocation const&) @ 0x000000003aa26aef 12. ./build_docker/./src/Client/HedgedConnections.cpp:389: DB::HedgedConnections::getReadyReplicaLocation(std::function) @ 0x000000003aa23dd3 13. ./build_docker/./src/Client/HedgedConnections.cpp:363: DB::HedgedConnections::receivePacketUnlocked(std::function) @ 0x000000003aa262eb 14. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f23f654 15. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 16. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 17. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 2025.06.13 08:44:37.672330 [ 3514 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 7.26 MiB (attempt to allocate chunk of 1.00 MiB bytes), maximum: 6.68 MiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./src/Common/FiberStack.h:65: FiberStack::allocate() const @ 0x000000002f23af12 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:312: boost::context::detail::fiber_activation_record* boost::context::detail::create_fiber1>(FiberStack&, Fiber::RoutineImpl&&) @ 0x000000002f23942a 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:449: DB::AsyncTaskExecutor::createFiber() @ 0x000000002f237e7d 10. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:19: DB::AsyncTaskExecutor::resume() @ 0x000000002f237b99 11. ./build_docker/./src/Client/HedgedConnections.cpp:410: DB::HedgedConnections::resumePacketReceiver(DB::HedgedConnections::ReplicaLocation const&) @ 0x000000003aa26aef 12. ./build_docker/./src/Client/HedgedConnections.cpp:389: DB::HedgedConnections::getReadyReplicaLocation(std::function) @ 0x000000003aa23dd3 13. ./build_docker/./src/Client/HedgedConnections.cpp:363: DB::HedgedConnections::receivePacketUnlocked(std::function) @ 0x000000003aa262eb 14. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f23f654 15. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 16. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 17. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:44:37.748716 [ 2136 ] {763fff33-34c7-4af0-bd7c-35fed49bfd1a} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:34860). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc8fc3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2569: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000003adc01f6 7. ./build_docker/./src/Server/TCPHandler.cpp:823: DB::TCPHandler::runImpl() @ 0x000000003ad8f4fc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:44:37.754337 [ 2133 ] {3f6efad8-738d-4d9e-87bd-a16a35024ba4} executeQuery: Code: 36. DB::Exception: TTL expression now() + toIntervalMonth(1) does not depend on any of the columns of the table. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34406) (comment: 02296_ttl_non_deterministic.sql) (query 2, line 5) (in query: CREATE TABLE t_ttl_non_deterministic (`A` Int64) ENGINE = MergeTree ORDER BY A TTL now() + toIntervalMonth(1) SETTINGS index_granularity = 11896, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 401501877, compact_parts_max_bytes_to_buffer = 289384962, compact_parts_max_granules_to_buffer = 90, compact_parts_merge_max_bytes_to_prefetch_part = 6353315, merge_max_block_size = 14738, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 2296611809, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26347733, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 48, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = false, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 99702, primary_key_compress_block_size = 43390, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/TTLDescription.cpp:75: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x0000000038dcaec9 5. ./build_docker/./src/Storages/TTLDescription.cpp:407: DB::TTLTableDescription::getTTLForTableFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x0000000038dcf106 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:701: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37b239 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:44:37.756361 [ 2133 ] {} TCPHandler: Code: 36. DB::Exception: TTL expression now() + toIntervalMonth(1) does not depend on any of the columns of the table. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/TTLDescription.cpp:75: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x0000000038dcaec9 5. ./build_docker/./src/Storages/TTLDescription.cpp:407: DB::TTLTableDescription::getTTLForTableFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x0000000038dcf106 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:701: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37b239 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:44:37.792135 [ 2133 ] {25c12ce8-3f52-4d5a-b445-3aeedb8d9de6} executeQuery: Code: 36. DB::Exception: TTL expression now() + toIntervalMonth(1) does not depend on any of the columns of the table. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34406) (comment: 02296_ttl_non_deterministic.sql) (query 3, line 8) (in query: CREATE TABLE t_ttl_non_deterministic (`A` Int64) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/ttl1', '1') ORDER BY A TTL now() + toIntervalMonth(1) SETTINGS index_granularity = 11896, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 401501877, compact_parts_max_bytes_to_buffer = 289384962, compact_parts_max_granules_to_buffer = 90, compact_parts_merge_max_bytes_to_prefetch_part = 6353315, merge_max_block_size = 14738, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 2296611809, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26347733, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 48, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = false, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 99702, primary_key_compress_block_size = 43390, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/TTLDescription.cpp:75: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x0000000038dcaec9 5. ./build_docker/./src/Storages/TTLDescription.cpp:407: DB::TTLTableDescription::getTTLForTableFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x0000000038dcf106 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:701: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37b239 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:44:37.793899 [ 2133 ] {} TCPHandler: Code: 36. DB::Exception: TTL expression now() + toIntervalMonth(1) does not depend on any of the columns of the table. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/TTLDescription.cpp:75: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x0000000038dcaec9 5. ./build_docker/./src/Storages/TTLDescription.cpp:407: DB::TTLTableDescription::getTTLForTableFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x0000000038dcf106 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:701: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37b239 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:44:38.151771 [ 2133 ] {b1db4989-92cb-4589-8df1-0bd900d8dac3} executeQuery: Code: 36. DB::Exception: TTL expression now() + toIntervalMonth(1) does not depend on any of the columns of the table. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34406) (comment: 02296_ttl_non_deterministic.sql) (query 5, line 13) (in query: ALTER TABLE t_ttl_non_deterministic MODIFY TTL now() + toIntervalMonth(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/TTLDescription.cpp:75: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x0000000038dcaec9 5. ./build_docker/./src/Storages/TTLDescription.cpp:407: DB::TTLTableDescription::getTTLForTableFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x0000000038dcf106 6. ./build_docker/./src/Storages/AlterCommands.cpp:864: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000381728be 7. ./build_docker/./src/Storages/AlterCommands.cpp:1263: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000003818ab70 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003981884d 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:44:38.153707 [ 2133 ] {} TCPHandler: Code: 36. DB::Exception: TTL expression now() + toIntervalMonth(1) does not depend on any of the columns of the table. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/TTLDescription.cpp:75: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x0000000038dcaec9 5. ./build_docker/./src/Storages/TTLDescription.cpp:407: DB::TTLTableDescription::getTTLForTableFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x0000000038dcf106 6. ./build_docker/./src/Storages/AlterCommands.cpp:864: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000381728be 7. ./build_docker/./src/Storages/AlterCommands.cpp:1263: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000003818ab70 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003981884d 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:44:38.528206 [ 2133 ] {b309479a-b454-41eb-a3bf-597304593eb2} executeQuery: Code: 36. DB::Exception: TTL expression now() + toIntervalMonth(1) does not depend on any of the columns of the table. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34406) (comment: 02296_ttl_non_deterministic.sql) (query 8, line 17) (in query: ALTER TABLE t_ttl_non_deterministic MODIFY TTL now() + toIntervalMonth(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/TTLDescription.cpp:75: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x0000000038dcaec9 5. ./build_docker/./src/Storages/TTLDescription.cpp:407: DB::TTLTableDescription::getTTLForTableFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x0000000038dcf106 6. ./build_docker/./src/Storages/AlterCommands.cpp:864: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000381728be 7. ./build_docker/./src/Storages/AlterCommands.cpp:1263: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000003818ab70 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003981884d 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:44:38.530846 [ 2133 ] {} TCPHandler: Code: 36. DB::Exception: TTL expression now() + toIntervalMonth(1) does not depend on any of the columns of the table. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/TTLDescription.cpp:75: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x0000000038dcaec9 5. ./build_docker/./src/Storages/TTLDescription.cpp:407: DB::TTLTableDescription::getTTLForTableFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x0000000038dcf106 6. ./build_docker/./src/Storages/AlterCommands.cpp:864: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000381728be 7. ./build_docker/./src/Storages/AlterCommands.cpp:1263: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000003818ab70 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003981884d 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:44:39.158513 [ 2133 ] {d0db844e-4091-4590-8ada-41b400600624} executeQuery: Code: 36. DB::Exception: TTL expression now() + toIntervalMonth(1) does not depend on any of the columns of the table. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34406) (comment: 02296_ttl_non_deterministic.sql) (query 10, line 21) (in query: CREATE TABLE t_ttl_non_deterministic (`A` Int64, `B` Int64 TTL now() + toIntervalMonth(1)) ENGINE = MergeTree ORDER BY A SETTINGS index_granularity = 11896, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 401501877, compact_parts_max_bytes_to_buffer = 289384962, compact_parts_max_granules_to_buffer = 90, compact_parts_merge_max_bytes_to_prefetch_part = 6353315, merge_max_block_size = 14738, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 2296611809, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26347733, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 48, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = false, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 99702, primary_key_compress_block_size = 43390, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/TTLDescription.cpp:75: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x0000000038dcaec9 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:772: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37d80e 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:44:39.169029 [ 2133 ] {} TCPHandler: Code: 36. DB::Exception: TTL expression now() + toIntervalMonth(1) does not depend on any of the columns of the table. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/TTLDescription.cpp:75: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x0000000038dcaec9 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:772: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37d80e 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:44:39.195738 [ 3514 ] {20d5eb3e-9eaf-4f26-9b8e-50404d2d6011} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 7.26 MiB (attempt to allocate chunk of 1.00 MiB bytes), maximum: 7.15 MiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34408) (comment: 00133_long_shard_memory_tracker_and_exception_safety.sh) (query 1, line 2) (in query: SELECT intDiv(number, 5) AS k, max(toString(number)) FROM remote('127.0.0.{2,3}', test_kuhweop8.numbers_100k) GROUP BY k ORDER BY k LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./src/Common/FiberStack.h:65: FiberStack::allocate() const @ 0x000000002f23af12 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:312: boost::context::detail::fiber_activation_record* boost::context::detail::create_fiber1>(FiberStack&, Fiber::RoutineImpl&&) @ 0x000000002f23942a 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:449: DB::AsyncTaskExecutor::createFiber() @ 0x000000002f237e7d 10. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:19: DB::AsyncTaskExecutor::resume() @ 0x000000002f237b99 11. ./build_docker/./src/Client/HedgedConnections.cpp:410: DB::HedgedConnections::resumePacketReceiver(DB::HedgedConnections::ReplicaLocation const&) @ 0x000000003aa26aef 12. ./build_docker/./src/Client/HedgedConnections.cpp:389: DB::HedgedConnections::getReadyReplicaLocation(std::function) @ 0x000000003aa23dd3 13. ./build_docker/./src/Client/HedgedConnections.cpp:363: DB::HedgedConnections::receivePacketUnlocked(std::function) @ 0x000000003aa262eb 14. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f23f654 15. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 16. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 17. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 2025.06.13 08:44:39.214167 [ 2133 ] {bfbf0548-8a2d-40f1-9f8a-e4e7245a5021} executeQuery: Code: 36. DB::Exception: TTL expression now() + toIntervalMonth(1) does not depend on any of the columns of the table. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34406) (comment: 02296_ttl_non_deterministic.sql) (query 11, line 24) (in query: CREATE TABLE t_ttl_non_deterministic (`A` Int64, `B` Int64 TTL now() + toIntervalMonth(1)) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/ttl3', '1') ORDER BY A SETTINGS index_granularity = 11896, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 401501877, compact_parts_max_bytes_to_buffer = 289384962, compact_parts_max_granules_to_buffer = 90, compact_parts_merge_max_bytes_to_prefetch_part = 6353315, merge_max_block_size = 14738, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 2296611809, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26347733, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 48, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = false, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 99702, primary_key_compress_block_size = 43390, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/TTLDescription.cpp:75: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x0000000038dcaec9 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:772: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37d80e 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:44:39.225082 [ 2133 ] {} TCPHandler: Code: 36. DB::Exception: TTL expression now() + toIntervalMonth(1) does not depend on any of the columns of the table. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/TTLDescription.cpp:75: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x0000000038dcaec9 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:772: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37d80e 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:44:39.247749 [ 3514 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 7.26 MiB (attempt to allocate chunk of 1.00 MiB bytes), maximum: 7.15 MiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./src/Common/FiberStack.h:65: FiberStack::allocate() const @ 0x000000002f23af12 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:312: boost::context::detail::fiber_activation_record* boost::context::detail::create_fiber1>(FiberStack&, Fiber::RoutineImpl&&) @ 0x000000002f23942a 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:449: DB::AsyncTaskExecutor::createFiber() @ 0x000000002f237e7d 10. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:19: DB::AsyncTaskExecutor::resume() @ 0x000000002f237b99 11. ./build_docker/./src/Client/HedgedConnections.cpp:410: DB::HedgedConnections::resumePacketReceiver(DB::HedgedConnections::ReplicaLocation const&) @ 0x000000003aa26aef 12. ./build_docker/./src/Client/HedgedConnections.cpp:389: DB::HedgedConnections::getReadyReplicaLocation(std::function) @ 0x000000003aa23dd3 13. ./build_docker/./src/Client/HedgedConnections.cpp:363: DB::HedgedConnections::receivePacketUnlocked(std::function) @ 0x000000003aa262eb 14. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f23f654 15. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 16. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 17. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:44:39.304994 [ 2136 ] {f2323bd8-9b4b-4e50-9062-87b8d92695a2} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:34872). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc8fc3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2569: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000003adc01f6 7. ./build_docker/./src/Server/TCPHandler.cpp:823: DB::TCPHandler::runImpl() @ 0x000000003ad8f4fc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:44:39.619982 [ 2133 ] {0dbb4f0c-e8e2-43db-b8f0-c482c21f3833} executeQuery: Code: 36. DB::Exception: TTL expression now() + toIntervalMonth(1) does not depend on any of the columns of the table. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34406) (comment: 02296_ttl_non_deterministic.sql) (query 13, line 29) (in query: ALTER TABLE t_ttl_non_deterministic MODIFY COLUMN B Int64 TTL now() + toIntervalMonth(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/TTLDescription.cpp:75: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x0000000038dcaec9 5. ./build_docker/./src/Storages/AlterCommands.cpp:1341: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000003818c8e9 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003981884d 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:44:39.623792 [ 2133 ] {} TCPHandler: Code: 36. DB::Exception: TTL expression now() + toIntervalMonth(1) does not depend on any of the columns of the table. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/TTLDescription.cpp:75: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x0000000038dcaec9 5. ./build_docker/./src/Storages/AlterCommands.cpp:1341: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000003818c8e9 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003981884d 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:44:39.799305 [ 2133 ] {10ea50ac-bde5-4ceb-ba53-f3f9be05634f} executeQuery: Code: 36. DB::Exception: TTL expression now() + toIntervalMonth(1) does not depend on any of the columns of the table. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34406) (comment: 02296_ttl_non_deterministic.sql) (query 16, line 33) (in query: ALTER TABLE t_ttl_non_deterministic MODIFY COLUMN B Int64 TTL now() + toIntervalMonth(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/TTLDescription.cpp:75: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x0000000038dcaec9 5. ./build_docker/./src/Storages/AlterCommands.cpp:1341: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000003818c8e9 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003981884d 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:44:39.801085 [ 2133 ] {} TCPHandler: Code: 36. DB::Exception: TTL expression now() + toIntervalMonth(1) does not depend on any of the columns of the table. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/TTLDescription.cpp:75: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x0000000038dcaec9 5. ./build_docker/./src/Storages/AlterCommands.cpp:1341: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000003818c8e9 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003981884d 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:44:41.662084 [ 3514 ] {f698e9d4-1158-4e84-9e2c-7a0f14436e5f} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 8.40 MiB (attempt to allocate chunk of 1.14 MiB bytes), maximum: 7.63 MiB.: while receiving packet from 127.0.0.2:9000: While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34430) (comment: 00133_long_shard_memory_tracker_and_exception_safety.sh) (query 1, line 2) (in query: SELECT intDiv(number, 5) AS k, max(toString(number)) FROM remote('127.0.0.{2,3}', test_kuhweop8.numbers_100k) GROUP BY k ORDER BY k LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f53d7c4 8. ./src/IO/BufferWithOwnMemory.h:98: DB::Memory>::resize(unsigned long) @ 0x000000001f8de3ac 9. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:21: non-virtual thunk to DB::CompressedReadBuffer::nextImpl() @ 0x000000003dbfcbb6 10. DB::ReadBuffer::next() @ 0x0000000008e83ccf 11. ./src/IO/ReadBuffer.h:96: DB::NativeReader::read() @ 0x000000003afae2df 12. ./build_docker/./src/Client/Connection.cpp:1362: DB::Connection::receiveDataImpl(DB::NativeReader&) @ 0x000000003a99eaca 13. ./build_docker/./src/Client/Connection.cpp:1343: DB::Connection::receivePacket() @ 0x000000003a999195 14. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aa95398 15. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 16. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 17. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 2025.06.13 08:44:41.745125 [ 3514 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 8.40 MiB (attempt to allocate chunk of 1.14 MiB bytes), maximum: 7.63 MiB.: while receiving packet from 127.0.0.2:9000: While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f53d7c4 8. ./src/IO/BufferWithOwnMemory.h:98: DB::Memory>::resize(unsigned long) @ 0x000000001f8de3ac 9. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:21: non-virtual thunk to DB::CompressedReadBuffer::nextImpl() @ 0x000000003dbfcbb6 10. DB::ReadBuffer::next() @ 0x0000000008e83ccf 11. ./src/IO/ReadBuffer.h:96: DB::NativeReader::read() @ 0x000000003afae2df 12. ./build_docker/./src/Client/Connection.cpp:1362: DB::Connection::receiveDataImpl(DB::NativeReader&) @ 0x000000003a99eaca 13. ./build_docker/./src/Client/Connection.cpp:1343: DB::Connection::receivePacket() @ 0x000000003a999195 14. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aa95398 15. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 16. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 17. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:44:43.879215 [ 2134 ] {f393a114-9e70-4e52-a323-676b0d279469} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 8.45 MiB (attempt to allocate chunk of 1.18 MiB bytes), maximum: 8.11 MiB.: while receiving packet from 127.0.0.3:9000: While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34482) (comment: 00133_long_shard_memory_tracker_and_exception_safety.sh) (query 1, line 2) (in query: SELECT intDiv(number, 5) AS k, max(toString(number)) FROM remote('127.0.0.{2,3}', test_kuhweop8.numbers_100k) GROUP BY k ORDER BY k LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f53d7c4 8. ./src/IO/BufferWithOwnMemory.h:98: DB::Memory>::resize(unsigned long) @ 0x000000001f8de3ac 9. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:21: non-virtual thunk to DB::CompressedReadBuffer::nextImpl() @ 0x000000003dbfcbb6 10. DB::ReadBuffer::next() @ 0x0000000008e83ccf 11. ./src/IO/ReadBuffer.h:96: DB::NativeReader::read() @ 0x000000003afae2df 12. ./build_docker/./src/Client/Connection.cpp:1362: DB::Connection::receiveDataImpl(DB::NativeReader&) @ 0x000000003a99eaca 13. ./build_docker/./src/Client/Connection.cpp:1343: DB::Connection::receivePacket() @ 0x000000003a999195 14. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aa95398 15. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 16. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 17. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 2025.06.13 08:44:43.942336 [ 2134 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 8.45 MiB (attempt to allocate chunk of 1.18 MiB bytes), maximum: 8.11 MiB.: while receiving packet from 127.0.0.3:9000: While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f53d7c4 8. ./src/IO/BufferWithOwnMemory.h:98: DB::Memory>::resize(unsigned long) @ 0x000000001f8de3ac 9. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:21: non-virtual thunk to DB::CompressedReadBuffer::nextImpl() @ 0x000000003dbfcbb6 10. DB::ReadBuffer::next() @ 0x0000000008e83ccf 11. ./src/IO/ReadBuffer.h:96: DB::NativeReader::read() @ 0x000000003afae2df 12. ./build_docker/./src/Client/Connection.cpp:1362: DB::Connection::receiveDataImpl(DB::NativeReader&) @ 0x000000003a99eaca 13. ./build_docker/./src/Client/Connection.cpp:1343: DB::Connection::receivePacket() @ 0x000000003a999195 14. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aa95398 15. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 16. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 17. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:44:44.041819 [ 2133 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:34886, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fbc2c6f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fbc3c01 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9b2eba 6. DB::ReadBuffer::next() @ 0x0000000008e83ccf 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003ad8c853 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:44:44.046752 [ 2133 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:34886, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fbc2c6f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fbc3c01 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9b2eba 6. DB::ReadBuffer::next() @ 0x0000000008e83ccf 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003ad8c853 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:44:45.387310 [ 2141 ] {e14de8e4-7e8c-4bb5-81de-eb48b883156d} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:58628). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:58628) (comment: 00133_long_shard_memory_tracker_and_exception_safety.sh) (query 1, line 2) (in query: SELECT intDiv(`__table1`.`number`, 5) AS `k`, max(toString(`__table1`.`number`)) AS `max(toString(number))` FROM `test_kuhweop8`.`numbers_100k` AS `__table1` GROUP BY intDiv(`__table1`.`number`, 5) ORDER BY intDiv(`__table1`.`number`, 5) ASC LIMIT _CAST(1, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc8fc3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2569: DB::TCPHandler::runImpl() @ 0x000000003ad8ebbd 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 2025.06.13 08:44:45.389604 [ 2141 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:58628). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc8fc3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2569: DB::TCPHandler::runImpl() @ 0x000000003ad8ebbd 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 2025.06.13 08:44:45.457375 [ 2134 ] {7cfbef8c-6ead-430e-b002-c70a597f66a2} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 9.98 MiB (attempt to allocate chunk of 1.72 MiB bytes), maximum: 8.58 MiB.: while receiving packet from 127.0.0.2:9000: While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58740) (comment: 00133_long_shard_memory_tracker_and_exception_safety.sh) (query 1, line 2) (in query: SELECT intDiv(number, 5) AS k, max(toString(number)) FROM remote('127.0.0.{2,3}', test_kuhweop8.numbers_100k) GROUP BY k ORDER BY k LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f53cbed 8. DB::Arena::addMemoryChunk(unsigned long) @ 0x000000000b109c91 9. DB::Arena::alignedAlloc(unsigned long, unsigned long) @ 0x000000000b109925 10. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:84: DB::SerializationAggregateFunction::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f4f5c23 11. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f4de523 12. ./build_docker/./src/Formats/NativeReader.cpp:97: DB::NativeReader::read() @ 0x000000003afb2698 13. ./build_docker/./src/Client/Connection.cpp:1362: DB::Connection::receiveDataImpl(DB::NativeReader&) @ 0x000000003a99eaca 14. ./build_docker/./src/Client/Connection.cpp:1343: DB::Connection::receivePacket() @ 0x000000003a999195 15. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aa95398 16. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 17. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 18. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 2025.06.13 08:44:45.481995 [ 2134 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 9.98 MiB (attempt to allocate chunk of 1.72 MiB bytes), maximum: 8.58 MiB.: while receiving packet from 127.0.0.2:9000: While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f53cbed 8. DB::Arena::addMemoryChunk(unsigned long) @ 0x000000000b109c91 9. DB::Arena::alignedAlloc(unsigned long, unsigned long) @ 0x000000000b109925 10. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:84: DB::SerializationAggregateFunction::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f4f5c23 11. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f4de523 12. ./build_docker/./src/Formats/NativeReader.cpp:97: DB::NativeReader::read() @ 0x000000003afb2698 13. ./build_docker/./src/Client/Connection.cpp:1362: DB::Connection::receiveDataImpl(DB::NativeReader&) @ 0x000000003a99eaca 14. ./build_docker/./src/Client/Connection.cpp:1343: DB::Connection::receivePacket() @ 0x000000003a999195 15. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aa95398 16. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 17. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 18. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:44:47.940876 [ 3992 ] {b52d82a1-04f1-4c3a-8e43-bd5271352800} executeQuery: Code: 433. DB::Exception: Delta codec argument must be unsigned integer. (ILLEGAL_CODEC_PARAMETER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58774) (comment: 01296_codecs_bad_arguments.sql) (query 4, line 5) (in query: CREATE TABLE delta_table (`id` UInt64 CODEC(Delta(tuple()))) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 44315, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 55, min_bytes_for_full_part_storage = 110376919, compact_parts_max_bytes_to_buffer = 228484095, compact_parts_max_granules_to_buffer = 179, compact_parts_merge_max_bytes_to_prefetch_part = 4874329, merge_max_block_size = 20784, old_parts_lifetime = 35., prefer_fetch_merged_part_size_threshold = 9962224840, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 8737107, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 12901, primary_key_compress_block_size = 60412, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Compression/CompressionCodecDelta.cpp:207: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl[abi:ne190107] (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x000000003dc47b2f 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003dc24a68 6. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000003dd4aff2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f4dc59d 8. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f4dcf01 9. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003dd4693f 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000328d07cd 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000328d60b9 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000328fff5d 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:44:47.947724 [ 3992 ] {} TCPHandler: Code: 433. DB::Exception: Delta codec argument must be unsigned integer. (ILLEGAL_CODEC_PARAMETER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Compression/CompressionCodecDelta.cpp:207: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl[abi:ne190107] (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x000000003dc47b2f 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003dc24a68 6. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000003dd4aff2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f4dc59d 8. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f4dcf01 9. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003dd4693f 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000328d07cd 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000328d60b9 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000328fff5d 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:44:47.957105 [ 2135 ] {224ed8d4-9ca1-44a5-a96a-a2c7e79bd183} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:58638). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:58638) (comment: 00133_long_shard_memory_tracker_and_exception_safety.sh) (query 1, line 2) (in query: SELECT intDiv(`__table1`.`number`, 5) AS `k`, max(toString(`__table1`.`number`)) AS `max(toString(number))` FROM `test_kuhweop8`.`numbers_100k` AS `__table1` GROUP BY intDiv(`__table1`.`number`, 5) ORDER BY intDiv(`__table1`.`number`, 5) ASC LIMIT _CAST(1, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc8fc3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2569: DB::TCPHandler::runImpl() @ 0x000000003ad8ebbd 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 2025.06.13 08:44:47.981953 [ 2135 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:58638). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc8fc3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2569: DB::TCPHandler::runImpl() @ 0x000000003ad8ebbd 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 2025.06.13 08:44:48.042140 [ 404 ] {1532d226-d5de-4489-b036-632f89a1cdb3} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 10.35 MiB (attempt to allocate chunk of 2.06 MiB bytes), maximum: 9.06 MiB.: while receiving packet from 127.0.0.2:9000: While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58772) (comment: 00133_long_shard_memory_tracker_and_exception_safety.sh) (query 1, line 2) (in query: SELECT intDiv(number, 5) AS k, max(toString(number)) FROM remote('127.0.0.{2,3}', test_kuhweop8.numbers_100k) GROUP BY k ORDER BY k LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f53cbed 8. DB::Arena::addMemoryChunk(unsigned long) @ 0x000000000b109c91 9. DB::Arena::alignedAlloc(unsigned long, unsigned long) @ 0x000000000b109925 10. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:84: DB::SerializationAggregateFunction::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f4f5c23 11. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f4de523 12. ./build_docker/./src/Formats/NativeReader.cpp:97: DB::NativeReader::read() @ 0x000000003afb2698 13. ./build_docker/./src/Client/Connection.cpp:1362: DB::Connection::receiveDataImpl(DB::NativeReader&) @ 0x000000003a99eaca 14. ./build_docker/./src/Client/Connection.cpp:1343: DB::Connection::receivePacket() @ 0x000000003a999195 15. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aa95398 16. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 17. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 18. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 2025.06.13 08:44:48.072834 [ 404 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 10.35 MiB (attempt to allocate chunk of 2.06 MiB bytes), maximum: 9.06 MiB.: while receiving packet from 127.0.0.2:9000: While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f53cbed 8. DB::Arena::addMemoryChunk(unsigned long) @ 0x000000000b109c91 9. DB::Arena::alignedAlloc(unsigned long, unsigned long) @ 0x000000000b109925 10. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:84: DB::SerializationAggregateFunction::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f4f5c23 11. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f4de523 12. ./build_docker/./src/Formats/NativeReader.cpp:97: DB::NativeReader::read() @ 0x000000003afb2698 13. ./build_docker/./src/Client/Connection.cpp:1362: DB::Connection::receiveDataImpl(DB::NativeReader&) @ 0x000000003a99eaca 14. ./build_docker/./src/Client/Connection.cpp:1343: DB::Connection::receivePacket() @ 0x000000003a999195 15. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aa95398 16. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 17. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 18. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:44:48.175585 [ 3992 ] {c66537c7-882d-49fe-8441-1c73cf3f775e} executeQuery: Code: 433. DB::Exception: ZSTD codec argument must be integer. (ILLEGAL_CODEC_PARAMETER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58774) (comment: 01296_codecs_bad_arguments.sql) (query 5, line 6) (in query: CREATE TABLE zstd_table (`id` UInt64 CODEC(ZSTD(tuple()))) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 44315, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 55, min_bytes_for_full_part_storage = 110376919, compact_parts_max_bytes_to_buffer = 228484095, compact_parts_max_granules_to_buffer = 179, compact_parts_merge_max_bytes_to_prefetch_part = 4874329, merge_max_block_size = 20784, old_parts_lifetime = 35., prefer_fetch_merged_part_size_threshold = 9962224840, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 8737107, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 12901, primary_key_compress_block_size = 60412, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Compression/CompressionCodecZSTD.cpp:99: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:ne190107] (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x000000003dc37fcf 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003dc277b2 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003dc24a68 7. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000003dd4aff2 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f4dc59d 9. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f4dcf01 10. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003dd4693f 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000328d07cd 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000328d60b9 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000328fff5d 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:44:48.180993 [ 3992 ] {} TCPHandler: Code: 433. DB::Exception: ZSTD codec argument must be integer. (ILLEGAL_CODEC_PARAMETER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Compression/CompressionCodecZSTD.cpp:99: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:ne190107] (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x000000003dc37fcf 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003dc277b2 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003dc24a68 7. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000003dd4aff2 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f4dc59d 9. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f4dcf01 10. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003dd4693f 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000328d07cd 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000328d60b9 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000328fff5d 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:44:48.446493 [ 3992 ] {dedafb7a-1637-463a-8e2a-b7f6b2d12e9b} executeQuery: Code: 433. DB::Exception: LZ4HC codec argument must be integer. (ILLEGAL_CODEC_PARAMETER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58774) (comment: 01296_codecs_bad_arguments.sql) (query 6, line 7) (in query: CREATE TABLE lz4_table (`id` UInt64 CODEC(LZ4HC(tuple()))) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 44315, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 55, min_bytes_for_full_part_storage = 110376919, compact_parts_max_bytes_to_buffer = 228484095, compact_parts_max_granules_to_buffer = 179, compact_parts_merge_max_bytes_to_prefetch_part = 4874329, merge_max_block_size = 20784, old_parts_lifetime = 35., prefer_fetch_merged_part_size_threshold = 9962224840, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 8737107, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 12901, primary_key_compress_block_size = 60412, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Compression/CompressionCodecLZ4.cpp:134: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:ne190107] (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x000000003dc34693 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003dc277b2 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003dc24a68 7. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000003dd4aff2 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f4dc59d 9. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f4dcf01 10. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003dd4693f 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000328d07cd 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000328d60b9 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000328fff5d 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:44:48.451804 [ 3992 ] {} TCPHandler: Code: 433. DB::Exception: LZ4HC codec argument must be integer. (ILLEGAL_CODEC_PARAMETER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Compression/CompressionCodecLZ4.cpp:134: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:ne190107] (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x000000003dc34693 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003dc277b2 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003dc24a68 7. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000003dd4aff2 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f4dc59d 9. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f4dcf01 10. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003dd4693f 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000328d07cd 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000328d60b9 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000328fff5d 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:44:48.674325 [ 3992 ] {f782a716-d0ee-44ee-9270-eac3a3d362d2} executeQuery: Code: 378. DB::Exception: Compression codec LZ4 cannot have arguments. (DATA_TYPE_CANNOT_HAVE_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58774) (comment: 01296_codecs_bad_arguments.sql) (query 7, line 9) (in query: CREATE TABLE lz4_table (`id` UInt64 CODEC(LZ4(tuple()))) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 44315, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 55, min_bytes_for_full_part_storage = 110376919, compact_parts_max_bytes_to_buffer = 228484095, compact_parts_max_granules_to_buffer = 179, compact_parts_merge_max_bytes_to_prefetch_part = 4874329, merge_max_block_size = 20784, old_parts_lifetime = 35., prefer_fetch_merged_part_size_threshold = 9962224840, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 8737107, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 12901, primary_key_compress_block_size = 60412, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Compression/CompressionFactory.cpp:164: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:ne190107], std::function ()>)::$_0, std::shared_ptr (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x000000003dc27e05 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003dc277b2 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003dc24a68 7. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000003dd4aff2 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f4dc59d 9. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f4dcf01 10. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003dd4693f 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000328d07cd 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000328d60b9 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000328fff5d 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:44:48.683597 [ 3992 ] {} TCPHandler: Code: 378. DB::Exception: Compression codec LZ4 cannot have arguments. (DATA_TYPE_CANNOT_HAVE_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Compression/CompressionFactory.cpp:164: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:ne190107], std::function ()>)::$_0, std::shared_ptr (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x000000003dc27e05 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003dc277b2 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003dc24a68 7. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000003dd4aff2 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f4dc59d 9. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f4dcf01 10. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003dd4693f 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000328d07cd 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000328d60b9 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000328fff5d 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:44:50.266945 [ 2134 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:58644, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fbc2c6f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fbc3c01 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9b2eba 6. DB::ReadBuffer::next() @ 0x0000000008e83ccf 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003ad8c853 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:44:50.267430 [ 2134 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:58644, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fbc2c6f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fbc3c01 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9b2eba 6. DB::ReadBuffer::next() @ 0x0000000008e83ccf 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003ad8c853 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:44:50.294948 [ 2135 ] {105a5ab6-df40-453b-a415-f7916e5a9b19} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 10.19 MiB (attempt to allocate chunk of 1.72 MiB bytes), maximum: 9.54 MiB.: while receiving packet from 127.0.0.2:9000: While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58786) (comment: 00133_long_shard_memory_tracker_and_exception_safety.sh) (query 1, line 2) (in query: SELECT intDiv(number, 5) AS k, max(toString(number)) FROM remote('127.0.0.{2,3}', test_kuhweop8.numbers_100k) GROUP BY k ORDER BY k LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f53cbed 8. DB::Arena::addMemoryChunk(unsigned long) @ 0x000000000b109c91 9. DB::Arena::alignedAlloc(unsigned long, unsigned long) @ 0x000000000b109925 10. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:84: DB::SerializationAggregateFunction::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f4f5c23 11. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f4de523 12. ./build_docker/./src/Formats/NativeReader.cpp:97: DB::NativeReader::read() @ 0x000000003afb2698 13. ./build_docker/./src/Client/Connection.cpp:1362: DB::Connection::receiveDataImpl(DB::NativeReader&) @ 0x000000003a99eaca 14. ./build_docker/./src/Client/Connection.cpp:1343: DB::Connection::receivePacket() @ 0x000000003a999195 15. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aa95398 16. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 17. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 18. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 2025.06.13 08:44:50.358468 [ 2135 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 10.19 MiB (attempt to allocate chunk of 1.72 MiB bytes), maximum: 9.54 MiB.: while receiving packet from 127.0.0.2:9000: While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f53cbed 8. DB::Arena::addMemoryChunk(unsigned long) @ 0x000000000b109c91 9. DB::Arena::alignedAlloc(unsigned long, unsigned long) @ 0x000000000b109925 10. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:84: DB::SerializationAggregateFunction::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f4f5c23 11. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f4de523 12. ./build_docker/./src/Formats/NativeReader.cpp:97: DB::NativeReader::read() @ 0x000000003afb2698 13. ./build_docker/./src/Client/Connection.cpp:1362: DB::Connection::receiveDataImpl(DB::NativeReader&) @ 0x000000003a99eaca 14. ./build_docker/./src/Client/Connection.cpp:1343: DB::Connection::receivePacket() @ 0x000000003a999195 15. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aa95398 16. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 17. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 18. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:44:50.400236 [ 3514 ] {055bbeca-f676-4827-a14f-75344b244085} executeQuery: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58800) (query 1, line 1) (in query: select _path,_file from file('nonexist.txt', 'CSV', 'val1 char')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/StorageFile.cpp:1630: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003841b9f8 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032b6f004 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032b5101c 7. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x0000000032afc62e 8. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:44:50.401487 [ 2133 ] {52e97fde-cf92-4ac4-b560-4e3766c1c236} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:35768). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2569: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000003adc01f6 7. ./build_docker/./src/Server/TCPHandler.cpp:823: DB::TCPHandler::runImpl() @ 0x000000003ad8f4fc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:44:50.404897 [ 3514 ] {} TCPHandler: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/StorageFile.cpp:1630: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003841b9f8 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032b6f004 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032b5101c 7. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x0000000032afc62e 8. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:44:51.123271 [ 404 ] {9a4cdc88-c18c-4dd2-8328-963db7eef21d} executeQuery: Code: 63. DB::Exception: Aggregate function with name 'abs' does not exist. In scope SELECT number, abs(number) OVER (PARTITION BY toString(intDiv(number, 3)) ROWS BETWEEN UNBOUNDED PRECEDING AND CURRENT ROW) FROM numbers(10). (UNKNOWN_AGGREGATE_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58796) (comment: 01591_window_functions.sql) (query 8, line 19) (in query: -- not a window function select number, abs(number) over (partition by toString(intDiv(number, 3)) rows unbounded preceding) from numbers(10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x0000000027757917 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3270: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003038c54c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:44:51.147155 [ 404 ] {} TCPHandler: Code: 63. DB::Exception: Aggregate function with name 'abs' does not exist. In scope SELECT number, abs(number) OVER (PARTITION BY toString(intDiv(number, 3)) ROWS BETWEEN UNBOUNDED PRECEDING AND CURRENT ROW) FROM numbers(10). (UNKNOWN_AGGREGATE_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x0000000027757917 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3270: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003038c54c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:44:52.997178 [ 2133 ] {8a0ace72-37af-4839-a44d-7679441a3aa4} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:35772) (comment: 00133_long_shard_memory_tracker_and_exception_safety.sh) (query 1, line 2) (in query: SELECT intDiv(`__table1`.`number`, 5) AS `k`, max(toString(`__table1`.`number`)) AS `max(toString(number))` FROM `test_kuhweop8`.`numbers_100k` AS `__table1` GROUP BY intDiv(`__table1`.`number`, 5) ORDER BY intDiv(`__table1`.`number`, 5) ASC LIMIT _CAST(1, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003adff16b 3. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003ade861b 4. ./build_docker/./src/Server/TCPHandler.cpp:1287: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe73a 5. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 08:44:53.002722 [ 2133 ] {8a0ace72-37af-4839-a44d-7679441a3aa4} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:35772). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2557: DB::TCPHandler::sendException(DB::Exception const&, bool) @ 0x000000003adb5f67 7. ./build_docker/./src/Server/TCPHandler.cpp:825: DB::TCPHandler::runImpl() @ 0x000000003ad8f542 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:44:53.012100 [ 2133 ] {} TCPHandler: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003adff16b 3. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003ade861b 4. ./build_docker/./src/Server/TCPHandler.cpp:1287: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe73a 5. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 08:44:53.099209 [ 2136 ] {1df115bf-d683-416c-b291-1e1a50dacbe5} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 10.42 MiB (attempt to allocate chunk of 2.06 MiB bytes), maximum: 9.63 MiB.: while receiving packet from 127.0.0.3:9000: While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58804) (comment: 00133_long_shard_memory_tracker_and_exception_safety.sh) (query 1, line 2) (in query: SELECT intDiv(number, 5) AS k, max(toString(number)) FROM remote('127.0.0.{2,3}', test_kuhweop8.numbers_100k) GROUP BY k ORDER BY k LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f53cbed 8. DB::Arena::addMemoryChunk(unsigned long) @ 0x000000000b109c91 9. DB::Arena::alignedAlloc(unsigned long, unsigned long) @ 0x000000000b109925 10. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:84: DB::SerializationAggregateFunction::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f4f5c23 11. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f4de523 12. ./build_docker/./src/Formats/NativeReader.cpp:97: DB::NativeReader::read() @ 0x000000003afb2698 13. ./build_docker/./src/Client/Connection.cpp:1362: DB::Connection::receiveDataImpl(DB::NativeReader&) @ 0x000000003a99eaca 14. ./build_docker/./src/Client/Connection.cpp:1343: DB::Connection::receivePacket() @ 0x000000003a999195 15. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aa95398 16. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 17. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 18. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 2025.06.13 08:44:53.105962 [ 3514 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:58648, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fbc2c6f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fbc3c01 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9b2eba 6. DB::ReadBuffer::next() @ 0x0000000008e83ccf 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003ad8c853 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:44:53.106331 [ 3514 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:58648, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fbc2c6f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fbc3c01 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9b2eba 6. DB::ReadBuffer::next() @ 0x0000000008e83ccf 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003ad8c853 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:44:53.261305 [ 2136 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 10.42 MiB (attempt to allocate chunk of 2.06 MiB bytes), maximum: 9.63 MiB.: while receiving packet from 127.0.0.3:9000: While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f53cbed 8. DB::Arena::addMemoryChunk(unsigned long) @ 0x000000000b109c91 9. DB::Arena::alignedAlloc(unsigned long, unsigned long) @ 0x000000000b109925 10. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:84: DB::SerializationAggregateFunction::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f4f5c23 11. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f4de523 12. ./build_docker/./src/Formats/NativeReader.cpp:97: DB::NativeReader::read() @ 0x000000003afb2698 13. ./build_docker/./src/Client/Connection.cpp:1362: DB::Connection::receiveDataImpl(DB::NativeReader&) @ 0x000000003a99eaca 14. ./build_docker/./src/Client/Connection.cpp:1343: DB::Connection::receivePacket() @ 0x000000003a999195 15. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aa95398 16. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 17. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 18. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:44:55.590520 [ 3992 ] {8378245f-93c2-425c-9812-376bbda6750a} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 12.51 MiB (attempt to allocate chunk of 1.22 MiB bytes), maximum: 12.02 MiB.: while receiving packet from 127.0.0.3:9000: While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56690) (comment: 00133_long_shard_memory_tracker_and_exception_safety.sh) (query 1, line 2) (in query: SELECT intDiv(number, 5) AS k, max(toString(number)) FROM remote('127.0.0.{2,3}', test_kuhweop8.numbers_100k) GROUP BY k ORDER BY k LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f53cbed 8. DB::Arena::addMemoryChunk(unsigned long) @ 0x000000000b109c91 9. DB::Arena::alignedAlloc(unsigned long, unsigned long) @ 0x000000000b109925 10. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:84: DB::SerializationAggregateFunction::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f4f5c23 11. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f4de523 12. ./build_docker/./src/Formats/NativeReader.cpp:97: DB::NativeReader::read() @ 0x000000003afb2698 13. ./build_docker/./src/Client/Connection.cpp:1362: DB::Connection::receiveDataImpl(DB::NativeReader&) @ 0x000000003a99eaca 14. ./build_docker/./src/Client/Connection.cpp:1343: DB::Connection::receivePacket() @ 0x000000003a999195 15. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aa95398 16. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 17. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 18. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 2025.06.13 08:44:55.636209 [ 3514 ] {e282cf66-ef97-4ef7-9eba-131362d92d41} executeQuery: Code: 475. DB::Exception: WITH FILL STEP value cannot be negative for sorting in ascending direction. (INVALID_WITH_FILL_EXPRESSION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56706) (comment: 00995_order_by_with_fill.sql) (query 16, line 34) (in query: SELECT * FROM fill ORDER BY a WITH FILL STEP -1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Planner/PlannerSorting.cpp:113: DB::extractSortDescription(std::shared_ptr const&, DB::PlannerContext const&) @ 0x0000000032c2f5b4 5. ./build_docker/./src/Planner/Planner.cpp:342: DB::Planner::buildPlanForQueryNode() @ 0x0000000032afe55b 6. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 08:44:55.640359 [ 3514 ] {} TCPHandler: Code: 475. DB::Exception: WITH FILL STEP value cannot be negative for sorting in ascending direction. (INVALID_WITH_FILL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Planner/PlannerSorting.cpp:113: DB::extractSortDescription(std::shared_ptr const&, DB::PlannerContext const&) @ 0x0000000032c2f5b4 5. ./build_docker/./src/Planner/Planner.cpp:342: DB::Planner::buildPlanForQueryNode() @ 0x0000000032afe55b 6. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 08:44:55.671678 [ 3992 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 12.51 MiB (attempt to allocate chunk of 1.22 MiB bytes), maximum: 12.02 MiB.: while receiving packet from 127.0.0.3:9000: While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f53cbed 8. DB::Arena::addMemoryChunk(unsigned long) @ 0x000000000b109c91 9. DB::Arena::alignedAlloc(unsigned long, unsigned long) @ 0x000000000b109925 10. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:84: DB::SerializationAggregateFunction::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f4f5c23 11. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f4de523 12. ./build_docker/./src/Formats/NativeReader.cpp:97: DB::NativeReader::read() @ 0x000000003afb2698 13. ./build_docker/./src/Client/Connection.cpp:1362: DB::Connection::receiveDataImpl(DB::NativeReader&) @ 0x000000003a99eaca 14. ./build_docker/./src/Client/Connection.cpp:1343: DB::Connection::receivePacket() @ 0x000000003a999195 15. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aa95398 16. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 17. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 18. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:44:55.802190 [ 3514 ] {d6a5ccbd-3791-4759-a805-c12d8493f88d} executeQuery: Code: 475. DB::Exception: WITH FILL TO value cannot be less than FROM value for sorting in ascending direction. (INVALID_WITH_FILL_EXPRESSION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56706) (comment: 00995_order_by_with_fill.sql) (query 17, line 35) (in query: SELECT * FROM fill ORDER BY a WITH FILL FROM 10 TO 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Planner/PlannerSorting.cpp:123: DB::extractSortDescription(std::shared_ptr const&, DB::PlannerContext const&) @ 0x0000000032c2f82a 5. ./build_docker/./src/Planner/Planner.cpp:342: DB::Planner::buildPlanForQueryNode() @ 0x0000000032afe55b 6. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 08:44:55.804390 [ 3514 ] {} TCPHandler: Code: 475. DB::Exception: WITH FILL TO value cannot be less than FROM value for sorting in ascending direction. (INVALID_WITH_FILL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Planner/PlannerSorting.cpp:123: DB::extractSortDescription(std::shared_ptr const&, DB::PlannerContext const&) @ 0x0000000032c2f82a 5. ./build_docker/./src/Planner/Planner.cpp:342: DB::Planner::buildPlanForQueryNode() @ 0x0000000032afe55b 6. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 08:44:55.964851 [ 3514 ] {6a029914-75d8-47cd-8fea-d36f02917f76} executeQuery: Code: 475. DB::Exception: WITH FILL FROM value cannot be less than TO value for sorting in descending direction. (INVALID_WITH_FILL_EXPRESSION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56706) (comment: 00995_order_by_with_fill.sql) (query 18, line 36) (in query: SELECT * FROM fill ORDER BY a DESC WITH FILL FROM 1 TO 10;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Planner/PlannerSorting.cpp:140: DB::extractSortDescription(std::shared_ptr const&, DB::PlannerContext const&) @ 0x0000000032c2f6f0 5. ./build_docker/./src/Planner/Planner.cpp:342: DB::Planner::buildPlanForQueryNode() @ 0x0000000032afe55b 6. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 08:44:55.967199 [ 3514 ] {} TCPHandler: Code: 475. DB::Exception: WITH FILL FROM value cannot be less than TO value for sorting in descending direction. (INVALID_WITH_FILL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Planner/PlannerSorting.cpp:140: DB::extractSortDescription(std::shared_ptr const&, DB::PlannerContext const&) @ 0x0000000032c2f6f0 5. ./build_docker/./src/Planner/Planner.cpp:342: DB::Planner::buildPlanForQueryNode() @ 0x0000000032afe55b 6. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 08:44:56.289398 [ 3514 ] {b66e232a-47d7-48a4-a6f6-134c46f8f367} executeQuery: Code: 475. DB::Exception: WITH FILL bound values cannot be negative for unsigned type UInt32. (INVALID_WITH_FILL_EXPRESSION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56706) (comment: 00995_order_by_with_fill.sql) (query 19, line 37) (in query: SELECT * FROM fill ORDER BY a WITH FILL FROM -10 to 10;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:268: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x000000003c01076a 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr, bool const&, 0>(std::allocator const&, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x000000003c00534e 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl[abi:ne190107] (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x000000003c004765 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f132626 8. ./build_docker/./src/QueryPipeline/Pipe.cpp:632: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f131799 9. ./build_docker/./src/QueryPipeline/QueryPipelineBuilder.cpp:135: DB::QueryPipelineBuilder::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f18a721 10. ./build_docker/./src/Processors/QueryPlan/FillingStep.cpp:50: DB::FillingStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0031f4 11. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049e11 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:44:56.291890 [ 3514 ] {} TCPHandler: Code: 475. DB::Exception: WITH FILL bound values cannot be negative for unsigned type UInt32. (INVALID_WITH_FILL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:268: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x000000003c01076a 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr, bool const&, 0>(std::allocator const&, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x000000003c00534e 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl[abi:ne190107] (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x000000003c004765 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f132626 8. ./build_docker/./src/QueryPipeline/Pipe.cpp:632: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f131799 9. ./build_docker/./src/QueryPipeline/QueryPipelineBuilder.cpp:135: DB::QueryPipelineBuilder::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f18a721 10. ./build_docker/./src/Processors/QueryPlan/FillingStep.cpp:50: DB::FillingStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0031f4 11. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049e11 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:44:58.541542 [ 2084 ] {ca84b697-d479-4881-a8a3-bbce6bf54e0b} executeQuery: Code: 36. DB::Exception: Primary key or secondary index contains a duplicate expression. To suppress this exception, rerun the command with setting 'allow_suspicious_indices = 1'. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56732) (comment: 02540_duplicate_primary_key.sql) (query 3, line 5) (in query: CREATE TABLE test (`coverage` DateTime, `haunt` Nullable(Float32) CODEC(Gorilla, ZSTD(1)), `sail` Nullable(Float32) CODEC(Gorilla, ZSTD(1)), `empowerment_turnstile` UInt8, `empowerment_haversack` Nullable(Int16), `empowerment_function` Nullable(Int16), `empowerment_guidance` Nullable(Int32), `empowerment_high` Nullable(Int32), `trading_id` Nullable(Int32), `guidance` Nullable(Int32), `empowerment_rawhide` Int32, `memo` Nullable(Int16), `oeuvre` Nullable(Int16), `bun` Nullable(Int16), `tramp` String, `anthropology_total` Nullable(Float32), `situation_name` String, `timing` Nullable(String), `NAME_cockroach` String, `NAME_toe` String, `business_error_methane` FixedString(110), `business_instrumentation_methane` FixedString(15), `market` UInt8, `crew_memo` Nullable(Int16), `crew_oeuvre` Nullable(Int16), `crew_fortnight` Nullable(Int16), `princess_memo` Nullable(Int16), `princess_oeuvre` Nullable(Int16), `princess_fortnight` Nullable(Int16), `emerald` Nullable(Float32), `cannon_crate` Nullable(String), `thinking` String, `SectorMen` String, `rage_name` Nullable(String), `DevelopmentalLigandName` String, `chard_heavy_quadrant` UInt64, `poster_effective` Nullable(String), PROJECTION chrysalis_trapezium_ham (SELECT empowerment_turnstile, toStartOfInterval(coverage, toIntervalMonth(1)), toStartOfWeek(coverage, 10), toStartOfInterval(coverage, toIntervalDay(1)), NAME_toe, NAME_cockroach, situation_name, memo, oeuvre, crew_memo, crew_oeuvre, bun, sum(multiIf(crew_memo IS NULL, 0, 1)), sum(multiIf(crew_oeuvre IS NULL, 0, 1)), sum(multiIf(crew_fortnight IS NULL, 0, 1)), max(toStartOfInterval(coverage, toIntervalDay(1))), max(CAST(CAST(toStartOfInterval(coverage, toIntervalDay(1)), 'Nullable(DATE)'), 'Nullable(TIMESTAMP)')), min(toStartOfInterval(coverage, toIntervalDay(1))), min(CAST(CAST(toStartOfInterval(coverage, toIntervalDay(1)), 'Nullable(DATE)'), 'Nullable(TIMESTAMP)')), count(), sum(1) GROUP BY empowerment_turnstile, toStartOfInterval(coverage, toIntervalMonth(1)), toStartOfWeek(coverage, 10), toStartOfInterval(coverage, toIntervalDay(1)), empowerment_turnstile, toStartOfInterval(coverage, toIntervalMonth(1)), toStartOfWeek(coverage, 10), toStartOfInterval(coverage, toIntervalDay(1)), NAME_toe, NAME_cockroach, situation_name, memo, oeuvre, crew_memo, crew_oeuvre, bun)) ENGINE = MergeTree PARTITION BY toYYYYMM(coverage) ORDER BY (coverage, situation_name, NAME_toe, NAME_cockroach) SETTINGS index_granularity = 50952, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.8275876641273499, replace_long_file_name_to_hash = true, max_file_name_length = 43, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 269863504, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 8410447, merge_max_block_size = 2662, old_parts_lifetime = 18., prefer_fetch_merged_part_size_threshold = 9125928901, vertical_merge_algorithm_min_rows_to_activate = 469653, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10574061577, index_granularity_bytes = 18773802, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 28159, primary_key_compress_block_size = 26182, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:310: DB::checkSuspiciousIndices(DB::ASTFunction const*) @ 0x000000003977ac2b 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:729: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x00000000397737d3 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:842: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000039777889 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:869: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000003975fc87 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:517: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000003975c601 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a38dc5f 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a38d037 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37f002 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:44:58.547794 [ 2084 ] {} TCPHandler: Code: 36. DB::Exception: Primary key or secondary index contains a duplicate expression. To suppress this exception, rerun the command with setting 'allow_suspicious_indices = 1'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:310: DB::checkSuspiciousIndices(DB::ASTFunction const*) @ 0x000000003977ac2b 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:729: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x00000000397737d3 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:842: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000039777889 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:869: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000003975fc87 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:517: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000003975c601 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a38dc5f 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a38d037 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37f002 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:44:58.794905 [ 404 ] {2a5c5949-f723-48fc-841f-99f4b5535dd9} executeQuery: Code: 36. DB::Exception: The function 'lagInFrame' can only be used as a window function, not as an aggregate function. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58796) (comment: 01591_window_functions.sql) (query 71, line 388) (in query: select lagInFrameOrNull(1) over ();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::WindowFunction::fail() const @ 0x000000003bc28bce 4. ./src/AggregateFunctions/WindowFunction.h:81: ? @ 0x000000003bc25589 5. ./src/AggregateFunctions/IAggregateFunction.h:552: DB::IAggregateFunctionHelper::addBatchSinglePlace(unsigned long, unsigned long, char*, DB::IColumn const**, DB::Arena*, long) const @ 0x000000003bc26864 6. ./src/AggregateFunctions/Combinators/AggregateFunctionOrFill.h:166: DB::AggregateFunctionOrFill::addBatchSinglePlace(unsigned long, unsigned long, char*, DB::IColumn const**, DB::Arena*, long) const @ 0x00000000265651dc 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1034: DB::WindowTransform::updateAggregationState() @ 0x000000003bc032a6 8. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1234: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x000000003bc05f08 9. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1462: DB::WindowTransform::work() @ 0x000000003bc0eadf 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 14. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 08:44:58.801108 [ 404 ] {} TCPHandler: Code: 36. DB::Exception: The function 'lagInFrame' can only be used as a window function, not as an aggregate function. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::WindowFunction::fail() const @ 0x000000003bc28bce 4. ./src/AggregateFunctions/WindowFunction.h:81: ? @ 0x000000003bc25589 5. ./src/AggregateFunctions/IAggregateFunction.h:552: DB::IAggregateFunctionHelper::addBatchSinglePlace(unsigned long, unsigned long, char*, DB::IColumn const**, DB::Arena*, long) const @ 0x000000003bc26864 6. ./src/AggregateFunctions/Combinators/AggregateFunctionOrFill.h:166: DB::AggregateFunctionOrFill::addBatchSinglePlace(unsigned long, unsigned long, char*, DB::IColumn const**, DB::Arena*, long) const @ 0x00000000265651dc 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1034: DB::WindowTransform::updateAggregationState() @ 0x000000003bc032a6 8. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1234: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x000000003bc05f08 9. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1462: DB::WindowTransform::work() @ 0x000000003bc0eadf 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 14. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:44:59.486688 [ 404 ] {9e6b318d-646c-44bf-8f70-d17c07fb23d5} executeQuery: Code: 36. DB::Exception: The offset for function nth_value must be in (1, 9223372036854775807], -1 given. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58796) (comment: 01591_window_functions.sql) (query 78, line 447) (in query: -- nth_value UBsan SELECT nth_value(1, -1) OVER ();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, long&&, long&) @ 0x000000003bc386f7 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2468: DB::WindowFunctionNthValue::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bc3804f 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: non-virtual thunk to DB::WindowFunctionNthValue::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bc3860d 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1051: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x000000003bc060fc 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1462: DB::WindowTransform::work() @ 0x000000003bc0eadf 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:44:59.500762 [ 404 ] {} TCPHandler: Code: 36. DB::Exception: The offset for function nth_value must be in (1, 9223372036854775807], -1 given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, long&&, long&) @ 0x000000003bc386f7 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2468: DB::WindowFunctionNthValue::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bc3804f 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: non-virtual thunk to DB::WindowFunctionNthValue::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bc3860d 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1051: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x000000003bc060fc 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1462: DB::WindowTransform::work() @ 0x000000003bc0eadf 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:44:59.530828 [ 404 ] {e2e1cf84-3a80-4739-a0c0-0f7d7d8cf3d3} executeQuery: Code: 36. DB::Exception: The offset for function nth_value must be in (1, 9223372036854775807], 0 given. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58796) (comment: 01591_window_functions.sql) (query 79, line 449) (in query: SELECT nth_value(1, 0) OVER ();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, long&&, long&) @ 0x000000003bc386f7 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2468: DB::WindowFunctionNthValue::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bc3804f 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: non-virtual thunk to DB::WindowFunctionNthValue::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bc3860d 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1051: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x000000003bc060fc 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1462: DB::WindowTransform::work() @ 0x000000003bc0eadf 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:44:59.539292 [ 404 ] {} TCPHandler: Code: 36. DB::Exception: The offset for function nth_value must be in (1, 9223372036854775807], 0 given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, long&&, long&) @ 0x000000003bc386f7 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2468: DB::WindowFunctionNthValue::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bc3804f 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: non-virtual thunk to DB::WindowFunctionNthValue::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bc3860d 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1051: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x000000003bc060fc 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1462: DB::WindowTransform::work() @ 0x000000003bc0eadf 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:44:59.592535 [ 404 ] {16ee1df8-7a34-420d-bbee-4bd1dd628aef} executeQuery: Code: 36. DB::Exception: The offset for function nth_value must be in (1, 9223372036854775807], -9223372036854775808 given. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58796) (comment: 01591_window_functions.sql) (query 80, line 450) (in query: SELECT nth_value(1, /* INT64_MAX+1 */ 0x7fffffffffffffff+1) OVER ();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, long&&, long&) @ 0x000000003bc386f7 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2468: DB::WindowFunctionNthValue::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bc3804f 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: non-virtual thunk to DB::WindowFunctionNthValue::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bc3860d 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1051: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x000000003bc060fc 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1462: DB::WindowTransform::work() @ 0x000000003bc0eadf 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:44:59.596866 [ 404 ] {} TCPHandler: Code: 36. DB::Exception: The offset for function nth_value must be in (1, 9223372036854775807], -9223372036854775808 given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, long&&, long&) @ 0x000000003bc386f7 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2468: DB::WindowFunctionNthValue::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bc3804f 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: non-virtual thunk to DB::WindowFunctionNthValue::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bc3860d 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1051: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x000000003bc060fc 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1462: DB::WindowTransform::work() @ 0x000000003bc0eadf 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:44:59.839063 [ 404 ] {ec2d6979-e743-4a27-b2e5-552fc09f49c5} executeQuery: Code: 36. DB::Exception: The offset for function lagInFrame must be in (0, 9223372036854775807], -1 given. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58796) (comment: 01591_window_functions.sql) (query 83, line 454) (in query: -- lagInFrame UBsan SELECT lagInFrame(1, -1) OVER ();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, long&&, long&) @ 0x000000003bc386f7 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2383: DB::WindowFunctionLagLeadInFrame::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bc3f596 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: non-virtual thunk to DB::WindowFunctionLagLeadInFrame::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bc3f98d 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1051: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x000000003bc060fc 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1462: DB::WindowTransform::work() @ 0x000000003bc0eadf 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:44:59.841551 [ 404 ] {} TCPHandler: Code: 36. DB::Exception: The offset for function lagInFrame must be in (0, 9223372036854775807], -1 given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, long&&, long&) @ 0x000000003bc386f7 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2383: DB::WindowFunctionLagLeadInFrame::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bc3f596 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: non-virtual thunk to DB::WindowFunctionLagLeadInFrame::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bc3f98d 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1051: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x000000003bc060fc 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1462: DB::WindowTransform::work() @ 0x000000003bc0eadf 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:44:59.922726 [ 404 ] {9c39ac32-6f38-4201-b733-a0304a9f0615} executeQuery: Code: 36. DB::Exception: The offset for function lagInFrame must be in (0, 9223372036854775807], -9223372036854775808 given. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58796) (comment: 01591_window_functions.sql) (query 85, line 457) (in query: SELECT lagInFrame(1, /* INT64_MAX+1 */ 0x7fffffffffffffff+1) OVER ();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, long&&, long&) @ 0x000000003bc386f7 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2383: DB::WindowFunctionLagLeadInFrame::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bc3f596 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: non-virtual thunk to DB::WindowFunctionLagLeadInFrame::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bc3f98d 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1051: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x000000003bc060fc 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1462: DB::WindowTransform::work() @ 0x000000003bc0eadf 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:44:59.925809 [ 404 ] {} TCPHandler: Code: 36. DB::Exception: The offset for function lagInFrame must be in (0, 9223372036854775807], -9223372036854775808 given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, long&&, long&) @ 0x000000003bc386f7 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2383: DB::WindowFunctionLagLeadInFrame::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bc3f596 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: non-virtual thunk to DB::WindowFunctionLagLeadInFrame::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bc3f98d 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1051: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x000000003bc060fc 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1462: DB::WindowTransform::work() @ 0x000000003bc0eadf 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:45:00.036083 [ 3992 ] {46c388e6-ad9a-488f-9c93-d87a249ba5fc} executeQuery: Code: 42. DB::Exception: Number of arguments for function timeSlots doesn't match: passed 1, should be 2 or 3: In scope SELECT timeSlots(toDateTime64('2000-01-02 03:04:05.23', 2, 'UTC')). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56776) (comment: 02319_timeslots_dt64.sql) (query 4, line 5) (in query: SELECT timeSlots(toDateTime64('2000-01-02 03:04:05.23', 2, 'UTC'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000008baf06d 4. DB::(anonymous namespace)::FunctionTimeSlots::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a9a6009 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:45:00.038060 [ 3992 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timeSlots doesn't match: passed 1, should be 2 or 3: In scope SELECT timeSlots(toDateTime64('2000-01-02 03:04:05.23', 2, 'UTC')). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000008baf06d 4. DB::(anonymous namespace)::FunctionTimeSlots::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a9a6009 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:45:00.061129 [ 3992 ] {00430245-5e1b-4453-89b6-f58c76d80901} executeQuery: Code: 42. DB::Exception: Number of arguments for function timeSlots doesn't match: passed 4, should be 2 or 3: In scope SELECT timeSlots(toDateTime64('2000-01-02 03:04:05.345', 3, 'UTC'), toDecimal64(62.3, 1), toDecimal64(12.34, 2), 'one more'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56776) (comment: 02319_timeslots_dt64.sql) (query 5, line 6) (in query: SELECT timeSlots(toDateTime64('2000-01-02 03:04:05.345', 3, 'UTC'), toDecimal64(62.3, 1), toDecimal64(12.34, 2), 'one more');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000008baf06d 4. DB::(anonymous namespace)::FunctionTimeSlots::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a9a6009 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:45:00.064594 [ 3992 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timeSlots doesn't match: passed 4, should be 2 or 3: In scope SELECT timeSlots(toDateTime64('2000-01-02 03:04:05.345', 3, 'UTC'), toDecimal64(62.3, 1), toDecimal64(12.34, 2), 'one more'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000008baf06d 4. DB::(anonymous namespace)::FunctionTimeSlots::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a9a6009 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:45:00.177287 [ 404 ] {abde7c9f-85b8-4022-90f0-d5f6d8ccc993} executeQuery: Code: 36. DB::Exception: The offset for function leadInFrame must be in (0, 9223372036854775807], -1 given. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58796) (comment: 01591_window_functions.sql) (query 88, line 461) (in query: -- leadInFrame UBsan SELECT leadInFrame(1, -1) OVER ();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, long&&, long&) @ 0x000000003bc386f7 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2383: DB::WindowFunctionLagLeadInFrame::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bc45bf6 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: non-virtual thunk to DB::WindowFunctionLagLeadInFrame::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bc45fed 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1051: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x000000003bc060fc 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1462: DB::WindowTransform::work() @ 0x000000003bc0eadf 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:45:00.190691 [ 404 ] {} TCPHandler: Code: 36. DB::Exception: The offset for function leadInFrame must be in (0, 9223372036854775807], -1 given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, long&&, long&) @ 0x000000003bc386f7 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2383: DB::WindowFunctionLagLeadInFrame::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bc45bf6 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: non-virtual thunk to DB::WindowFunctionLagLeadInFrame::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bc45fed 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1051: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x000000003bc060fc 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1462: DB::WindowTransform::work() @ 0x000000003bc0eadf 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:45:00.272582 [ 404 ] {107644c6-3797-4ca6-8c47-d00456b3d593} executeQuery: Code: 36. DB::Exception: The offset for function leadInFrame must be in (0, 9223372036854775807], -9223372036854775808 given. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58796) (comment: 01591_window_functions.sql) (query 90, line 464) (in query: SELECT leadInFrame(1, /* INT64_MAX+1 */ 0x7fffffffffffffff+1) OVER ();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, long&&, long&) @ 0x000000003bc386f7 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2383: DB::WindowFunctionLagLeadInFrame::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bc45bf6 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: non-virtual thunk to DB::WindowFunctionLagLeadInFrame::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bc45fed 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1051: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x000000003bc060fc 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1462: DB::WindowTransform::work() @ 0x000000003bc0eadf 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:45:00.275697 [ 404 ] {} TCPHandler: Code: 36. DB::Exception: The offset for function leadInFrame must be in (0, 9223372036854775807], -9223372036854775808 given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, long&&, long&) @ 0x000000003bc386f7 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2383: DB::WindowFunctionLagLeadInFrame::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bc45bf6 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: non-virtual thunk to DB::WindowFunctionLagLeadInFrame::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bc45fed 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1051: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x000000003bc060fc 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1462: DB::WindowTransform::work() @ 0x000000003bc0eadf 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:45:00.322473 [ 3992 ] {9ff164aa-e627-4816-8d56-c85e39634e60} executeQuery: Code: 43. DB::Exception: Illegal type String of second argument of function timeSlots. Must be Decimal64 when first argument is DateTime64.: In scope SELECT timeSlots(toDateTime64('2000-01-02 03:04:05.456', 3, 'UTC'), 'wrong argument'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56776) (comment: 02319_timeslots_dt64.sql) (query 6, line 7) (in query: SELECT timeSlots(toDateTime64('2000-01-02 03:04:05.456', 3, 'UTC'), 'wrong argument');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::(anonymous namespace)::FunctionTimeSlots::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a9a673f 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:45:00.324552 [ 3992 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of second argument of function timeSlots. Must be Decimal64 when first argument is DateTime64.: In scope SELECT timeSlots(toDateTime64('2000-01-02 03:04:05.456', 3, 'UTC'), 'wrong argument'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::(anonymous namespace)::FunctionTimeSlots::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a9a673f 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:45:00.411278 [ 2141 ] {} InterserverIOHTTPHandler: Code: 221. DB::Exception: No interserver IO endpoint named DataPartsExchange:default:/test/02448/test_26vbv78r/rmt/replicas/1. (NO_SUCH_INTERSERVER_IO_ENDPOINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./src/Interpreters/InterserverIOHandler.h:74: DB::InterserverIOHandler::getEndpoint(String const&) const @ 0x000000003ac1e048 5. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:66: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac181ce 6. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 7. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:45:00.614101 [ 3992 ] {eea573de-8032-47f7-a0f7-9b8eebf93653} executeQuery: Code: 43. DB::Exception: Illegal type String of third argument of function timeSlots. Must be Decimal64 when first argument is DateTime64.: In scope SELECT timeSlots(toDateTime64('2000-01-02 03:04:05.123', 3, 'UTC'), toDecimal64(600, 0), 'wrong argument'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56776) (comment: 02319_timeslots_dt64.sql) (query 7, line 8) (in query: SELECT timeSlots(toDateTime64('2000-01-02 03:04:05.123', 3, 'UTC'), toDecimal64(600, 0), 'wrong argument');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::(anonymous namespace)::FunctionTimeSlots::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a9a6aaf 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:45:00.616011 [ 3992 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of third argument of function timeSlots. Must be Decimal64 when first argument is DateTime64.: In scope SELECT timeSlots(toDateTime64('2000-01-02 03:04:05.123', 3, 'UTC'), toDecimal64(600, 0), 'wrong argument'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::(anonymous namespace)::FunctionTimeSlots::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a9a6aaf 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:45:00.666121 [ 404 ] {b8f73321-0772-4db3-97bc-6a5be31ec6de} executeQuery: Code: 36. DB::Exception: Offset must be an integer, 'String' given. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58796) (comment: 01591_window_functions.sql) (query 93, line 468) (in query: -- nth_value Msan SELECT nth_value(1, '') OVER ();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2435: DB::WindowFunctionNthValue::WindowFunctionNthValue(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc371c0 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc363d5 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000003bc121d7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d009bfb 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3285: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037c3e8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:45:00.668103 [ 404 ] {} TCPHandler: Code: 36. DB::Exception: Offset must be an integer, 'String' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2435: DB::WindowFunctionNthValue::WindowFunctionNthValue(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc371c0 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc363d5 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000003bc121d7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d009bfb 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3285: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037c3e8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:45:00.733537 [ 919 ] {} test_26vbv78r.rmt2 (ReplicatedMergeTreeCleanupThread): Will mark replica 1 as lost, because it has stale log pointer: log-0000000001 2025.06.13 08:45:00.910722 [ 3992 ] {68a0a69f-bc30-4721-ab4c-29781a36acce} executeQuery: Code: 44. DB::Exception: Third argument for function timeSlots must be greater than zero: In scope SELECT timeSlots(toDateTime64('2000-01-02 03:04:05.1232', 4, 'UTC'), toDecimal64(600, 0), toDecimal64(0, 0)). (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56776) (comment: 02319_timeslots_dt64.sql) (query 8, line 9) (in query: SELECT timeSlots(toDateTime64('2000-01-02 03:04:05.1232', 4, 'UTC'), toDecimal64(600, 0), toDecimal64(0, 0));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionTimeSlots::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a9a2cfe 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 08:45:00.927203 [ 3992 ] {} TCPHandler: Code: 44. DB::Exception: Third argument for function timeSlots must be greater than zero: In scope SELECT timeSlots(toDateTime64('2000-01-02 03:04:05.1232', 4, 'UTC'), toDecimal64(600, 0), toDecimal64(0, 0)). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionTimeSlots::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a9a2cfe 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 08:45:00.967271 [ 404 ] {a31defc7-7858-4665-8a47-c9cdc233225d} executeQuery: Code: 36. DB::Exception: Offset must be an integer, 'String' given. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58796) (comment: 01591_window_functions.sql) (query 94, line 471) (in query: -- lagInFrame Msan SELECT lagInFrame(1, '') OVER ();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2289: DB::WindowFunctionLagLeadInFrame::WindowFunctionLagLeadInFrame(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc3b6dc 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr> std::allocate_shared[abi:ne190107], std::allocator>, String const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator> const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc39775 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000003bc122d7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d009bfb 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3285: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037c3e8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:45:00.971475 [ 404 ] {} TCPHandler: Code: 36. DB::Exception: Offset must be an integer, 'String' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2289: DB::WindowFunctionLagLeadInFrame::WindowFunctionLagLeadInFrame(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc3b6dc 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr> std::allocate_shared[abi:ne190107], std::allocator>, String const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator> const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc39775 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000003bc122d7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d009bfb 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3285: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037c3e8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:45:01.230741 [ 404 ] {6c503890-a2c3-4eff-8335-71a265fac845} executeQuery: Code: 36. DB::Exception: Offset must be an integer, 'String' given. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58796) (comment: 01591_window_functions.sql) (query 95, line 474) (in query: -- leadInFrame Msan SELECT leadInFrame(1, '') OVER ();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2289: DB::WindowFunctionLagLeadInFrame::WindowFunctionLagLeadInFrame(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc41e3c 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr> std::allocate_shared[abi:ne190107], std::allocator>, String const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator> const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc3fed5 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000003bc123d7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d009bfb 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3285: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037c3e8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:45:01.232819 [ 404 ] {} TCPHandler: Code: 36. DB::Exception: Offset must be an integer, 'String' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2289: DB::WindowFunctionLagLeadInFrame::WindowFunctionLagLeadInFrame(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc41e3c 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr> std::allocate_shared[abi:ne190107], std::allocator>, String const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator> const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc3fed5 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000003bc123d7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d009bfb 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3285: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037c3e8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:45:01.671153 [ 404 ] {7fa62c7a-d7d1-417e-9667-9ee78787f89c} executeQuery: Code: 36. DB::Exception: Frame start offset for 'RANGE' frame must be a nonnegative 32-bit integer, '-1' of type 'Int64' given. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58796) (comment: 01591_window_functions.sql) (query 98, line 490) (in query: -- negative offsets should not be allowed select count() over (order by toInt64(number) range between -1 preceding and unbounded following) from numbers(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x0000000033647a57 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:100: DB::WindowFrame::checkValid() const @ 0x0000000033646df0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2564: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303b14aa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3290: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037c521 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:45:01.677750 [ 404 ] {} TCPHandler: Code: 36. DB::Exception: Frame start offset for 'RANGE' frame must be a nonnegative 32-bit integer, '-1' of type 'Int64' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x0000000033647a57 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:100: DB::WindowFrame::checkValid() const @ 0x0000000033646df0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2564: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303b14aa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3290: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037c521 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:45:01.712124 [ 404 ] {7cf569ad-27a0-4e74-afa9-d00e808e2b2b} executeQuery: Code: 36. DB::Exception: Frame start offset for 'RANGE' frame must be a nonnegative 32-bit integer, '-1' of type 'Int64' given. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58796) (comment: 01591_window_functions.sql) (query 99, line 492) (in query: select count() over (order by toInt64(number) range between -1 following and unbounded following) from numbers(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x0000000033647a57 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:100: DB::WindowFrame::checkValid() const @ 0x0000000033646df0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2564: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303b14aa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3290: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037c521 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:45:01.725770 [ 404 ] {} TCPHandler: Code: 36. DB::Exception: Frame start offset for 'RANGE' frame must be a nonnegative 32-bit integer, '-1' of type 'Int64' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x0000000033647a57 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:100: DB::WindowFrame::checkValid() const @ 0x0000000033646df0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2564: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303b14aa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3290: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037c521 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:45:01.896464 [ 1040 ] {} test_26vbv78r.rmt2 (2c6bb706-ccff-40c6-85e9-6c6d7d1e8344): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://e2c95b5d5426:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_26vbv78r%2Frmt%2Freplicas%2F1&part=all_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 2183 bytes, body: 'Code: 221. DB::Exception: No interserver IO endpoint named DataPartsExchange:default:/test/02448/test_26vbv78r/rmt/replicas/1. (NO_SUCH_INTERSERVER_IO_ENDPOINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./src/Interpreters/InterserverIOHandler.h:74: DB::InterserverIOHandler::getEndpoint(String const&) const @ 0x000000003ac1e048 5. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:66: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac181ce 6. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 7. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020149cb9 4. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020149637 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002668b3ca 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000002668b87c 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002668d238 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266944e7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 11. DB::ReadBuffer::next() @ 0x0000000008e83ccf 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 14. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 21. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 22. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:45:01.998448 [ 404 ] {889cd526-5636-4a1e-8de2-bb7e6ac5e869} executeQuery: Code: 36. DB::Exception: Frame end offset for 'RANGE' frame must be a nonnegative 32-bit integer, '-1' of type 'Int64' given. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58796) (comment: 01591_window_functions.sql) (query 100, line 493) (in query: select count() over (order by toInt64(number) range between unbounded preceding and -1 preceding) from numbers(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x0000000033647a57 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:113: DB::WindowFrame::checkValid() const @ 0x0000000033647057 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2564: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303b14aa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3290: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037c521 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:45:02.012550 [ 404 ] {} TCPHandler: Code: 36. DB::Exception: Frame end offset for 'RANGE' frame must be a nonnegative 32-bit integer, '-1' of type 'Int64' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x0000000033647a57 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:113: DB::WindowFrame::checkValid() const @ 0x0000000033647057 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2564: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303b14aa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3290: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037c521 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:45:02.041319 [ 404 ] {495bce4c-87d7-4f33-8f5a-a9623b5cb114} executeQuery: Code: 36. DB::Exception: Frame end offset for 'RANGE' frame must be a nonnegative 32-bit integer, '-1' of type 'Int64' given. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58796) (comment: 01591_window_functions.sql) (query 101, line 494) (in query: select count() over (order by toInt64(number) range between unbounded preceding and -1 following) from numbers(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x0000000033647a57 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:113: DB::WindowFrame::checkValid() const @ 0x0000000033647057 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2564: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303b14aa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3290: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037c521 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:45:02.051727 [ 404 ] {} TCPHandler: Code: 36. DB::Exception: Frame end offset for 'RANGE' frame must be a nonnegative 32-bit integer, '-1' of type 'Int64' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x0000000033647a57 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:113: DB::WindowFrame::checkValid() const @ 0x0000000033647057 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2564: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303b14aa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3290: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037c521 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:45:03.570292 [ 404 ] {fe838024-9ee8-4b98-abaf-b5d9f87238e4} executeQuery: Code: 36. DB::Exception: Frame start offset for 'ROWS' frame must be a nonnegative 32-bit integer, '2147483648' of type 'UInt64' given. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58796) (comment: 01591_window_functions.sql) (query 104, line 524) (in query: -- -INT_MIN row offset that can lead to problems with negation, found when fuzzing -- under UBSan. Should be limited to at most INT_MAX. select count() over (rows between 2147483648 preceding and 2147493648 following) from numbers(2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x0000000033647a57 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:100: DB::WindowFrame::checkValid() const @ 0x0000000033646df0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2564: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303b14aa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3290: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037c521 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:45:03.572481 [ 404 ] {} TCPHandler: Code: 36. DB::Exception: Frame start offset for 'ROWS' frame must be a nonnegative 32-bit integer, '2147483648' of type 'UInt64' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x0000000033647a57 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:100: DB::WindowFrame::checkValid() const @ 0x0000000033646df0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2564: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303b14aa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3290: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037c521 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:45:04.054726 [ 404 ] {07966838-fe5e-4814-b124-8d2cc4188a20} executeQuery: Code: 36. DB::Exception: Derived window definition 'w PARTITION BY number' is not allowed to override PARTITION BY. In scope SELECT count() OVER (w PARTITION BY number) FROM numbers(1) WINDOW w AS (PARTITION BY intDiv(number, 5)). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58796) (comment: 01591_window_functions.sql) (query 108, line 542) (in query: -- can't redefine PARTITION BY select count() over (w partition by number) from numbers(1) window w as (partition by intDiv(number, 5));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:775: DB::QueryAnalyzer::mergeWindowWithParentWindow(std::shared_ptr const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003034d301 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2505: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303afe5c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3290: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037c521 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:45:04.059000 [ 404 ] {} TCPHandler: Code: 36. DB::Exception: Derived window definition 'w PARTITION BY number' is not allowed to override PARTITION BY. In scope SELECT count() OVER (w PARTITION BY number) FROM numbers(1) WINDOW w AS (PARTITION BY intDiv(number, 5)). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:775: DB::QueryAnalyzer::mergeWindowWithParentWindow(std::shared_ptr const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003034d301 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2505: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303afe5c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3290: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037c521 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:45:04.299720 [ 404 ] {a36dbcf5-dc07-4716-8a19-1dc95987455f} executeQuery: Code: 36. DB::Exception: Derived window definition 'w ORDER BY number ASC' is not allowed to override a non-empty ORDER BY. In scope SELECT count() OVER (w ORDER BY number ASC) FROM numbers(1) WINDOW w AS (PARTITION BY intDiv(number, 5) ORDER BY mod(number, 3) ASC). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58796) (comment: 01591_window_functions.sql) (query 109, line 545) (in query: -- can't redefine existing ORDER BY select count() over (w order by number) from numbers(1) window w as (partition by intDiv(number, 5) order by mod(number, 3));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:783: DB::QueryAnalyzer::mergeWindowWithParentWindow(std::shared_ptr const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003034d882 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2505: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303afe5c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3290: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037c521 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:45:04.302368 [ 404 ] {} TCPHandler: Code: 36. DB::Exception: Derived window definition 'w ORDER BY number ASC' is not allowed to override a non-empty ORDER BY. In scope SELECT count() OVER (w ORDER BY number ASC) FROM numbers(1) WINDOW w AS (PARTITION BY intDiv(number, 5) ORDER BY mod(number, 3) ASC). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:783: DB::QueryAnalyzer::mergeWindowWithParentWindow(std::shared_ptr const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003034d882 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2505: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303afe5c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3290: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037c521 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:45:04.538529 [ 404 ] {7873b4a0-d192-46ca-ae53-6efdc97ab883} executeQuery: Code: 36. DB::Exception: Parent window 'w' is not allowed to define a frame: while processing derived window definition 'w RANGE BETWEEN UNBOUNDED PRECEDING AND CURRENT ROW'. In scope SELECT count() OVER (w RANGE BETWEEN UNBOUNDED PRECEDING AND CURRENT ROW) FROM numbers(1) WINDOW w AS (PARTITION BY intDiv(number, 5) ORDER BY mod(number, 3) ASC ROWS BETWEEN UNBOUNDED PRECEDING AND CURRENT ROW). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58796) (comment: 01591_window_functions.sql) (query 110, line 548) (in query: -- parent window can't have frame select count() over (w range unbounded preceding) from numbers(1) window w as (partition by intDiv(number, 5) order by mod(number, 3) rows unbounded preceding);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x0000000027757917 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:791: DB::QueryAnalyzer::mergeWindowWithParentWindow(std::shared_ptr const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003034d552 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2505: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303afe5c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3290: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037c521 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:45:04.542876 [ 404 ] {} TCPHandler: Code: 36. DB::Exception: Parent window 'w' is not allowed to define a frame: while processing derived window definition 'w RANGE BETWEEN UNBOUNDED PRECEDING AND CURRENT ROW'. In scope SELECT count() OVER (w RANGE BETWEEN UNBOUNDED PRECEDING AND CURRENT ROW) FROM numbers(1) WINDOW w AS (PARTITION BY intDiv(number, 5) ORDER BY mod(number, 3) ASC ROWS BETWEEN UNBOUNDED PRECEDING AND CURRENT ROW). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x0000000027757917 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:791: DB::QueryAnalyzer::mergeWindowWithParentWindow(std::shared_ptr const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003034d552 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2505: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303afe5c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3290: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037c521 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:45:04.793845 [ 404 ] {35d25a34-61eb-49da-8adf-991a74a85a39} executeQuery: Code: 36. DB::Exception: Window 'w2' does not exist. In scope SELECT count() OVER (w2 ROWS BETWEEN UNBOUNDED PRECEDING AND CURRENT ROW). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58796) (comment: 01591_window_functions.sql) (query 112, line 554) (in query: -- nonexistent parent window select count() over (w2 rows unbounded preceding);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000d2a1d0d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2491: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303b2aa0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3290: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037c521 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:45:04.799476 [ 404 ] {} TCPHandler: Code: 36. DB::Exception: Window 'w2' does not exist. In scope SELECT count() OVER (w2 ROWS BETWEEN UNBOUNDED PRECEDING AND CURRENT ROW). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000d2a1d0d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2491: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303b2aa0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3290: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037c521 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:45:05.787087 [ 3514 ] {37c0e155-ad6c-4b77-bbee-926f9f6be35c} InterpreterSystemQuery: SYNC REPLICA test_26vbv78r.rmt2 (2c6bb706-ccff-40c6-85e9-6c6d7d1e8344): Timed out. 2025.06.13 08:45:05.945891 [ 3514 ] {37c0e155-ad6c-4b77-bbee-926f9f6be35c} executeQuery: Code: 159. DB::Exception: SYNC REPLICA test_26vbv78r.rmt2 (2c6bb706-ccff-40c6-85e9-6c6d7d1e8344): command timed out. See the 'receive_timeout' setting. (TIMEOUT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56784) (comment: 02448_clone_replica_lost_part.sql) (query 15, line 32) (in query: system sync replica rmt2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1268: DB::InterpreterSystemQuery::trySyncReplica(std::shared_ptr, DB::SyncReplicaMode, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr) @ 0x0000000033828844 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1284: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x000000003380b8a6 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:763: DB::InterpreterSystemQuery::execute() @ 0x00000000337e4c52 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 08:45:05.954402 [ 3514 ] {} TCPHandler: Code: 159. DB::Exception: SYNC REPLICA test_26vbv78r.rmt2 (2c6bb706-ccff-40c6-85e9-6c6d7d1e8344): command timed out. See the 'receive_timeout' setting. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1268: DB::InterpreterSystemQuery::trySyncReplica(std::shared_ptr, DB::SyncReplicaMode, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr) @ 0x0000000033828844 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1284: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x000000003380b8a6 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:763: DB::InterpreterSystemQuery::execute() @ 0x00000000337e4c52 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 08:45:06.124411 [ 610 ] {} test_26vbv78r.rmt1 (069e43ce-7650-4ac3-afc5-602749a91cf3): Will mimic 2 2025.06.13 08:45:06.761829 [ 1045 ] {} test_26vbv78r.rmt1 (069e43ce-7650-4ac3-afc5-602749a91cf3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://e2c95b5d5426:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_26vbv78r%2Frmt%2Freplicas%2F2&part=all_7_7_0&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 136 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020149cb9 4. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020149637 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002668b3ca 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000002668b87c 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002668d238 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266944e7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 11. DB::ReadBuffer::next() @ 0x0000000008e83ccf 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 14. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 21. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 22. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:45:06.907536 [ 1040 ] {} test_26vbv78r.rmt1 (069e43ce-7650-4ac3-afc5-602749a91cf3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://e2c95b5d5426:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_26vbv78r%2Frmt%2Freplicas%2F2&part=all_7_7_0&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 136 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020149cb9 4. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020149637 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002668b3ca 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000002668b87c 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002668d238 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266944e7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 11. DB::ReadBuffer::next() @ 0x0000000008e83ccf 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 14. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 21. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 22. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:45:06.922424 [ 1053 ] {} test_26vbv78r.rmt1 (069e43ce-7650-4ac3-afc5-602749a91cf3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://e2c95b5d5426:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_26vbv78r%2Frmt%2Freplicas%2F2&part=all_8_8_0&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 136 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020149cb9 4. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020149637 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002668b3ca 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000002668b87c 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002668d238 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266944e7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 11. DB::ReadBuffer::next() @ 0x0000000008e83ccf 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 14. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 21. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 22. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:45:06.966413 [ 1051 ] {} test_26vbv78r.rmt1 (069e43ce-7650-4ac3-afc5-602749a91cf3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://e2c95b5d5426:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_26vbv78r%2Frmt%2Freplicas%2F2&part=all_7_7_0&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 136 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020149cb9 4. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020149637 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002668b3ca 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000002668b87c 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002668d238 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266944e7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 11. DB::ReadBuffer::next() @ 0x0000000008e83ccf 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 14. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 21. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 22. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:45:06.977484 [ 1042 ] {} test_26vbv78r.rmt1 (069e43ce-7650-4ac3-afc5-602749a91cf3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://e2c95b5d5426:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_26vbv78r%2Frmt%2Freplicas%2F2&part=all_8_8_0&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 136 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020149cb9 4. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020149637 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002668b3ca 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000002668b87c 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002668d238 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266944e7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 11. DB::ReadBuffer::next() @ 0x0000000008e83ccf 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 14. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 21. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 22. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:45:07.533410 [ 1019 ] {} 069e43ce-7650-4ac3-afc5-602749a91cf3::all_7_8_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://e2c95b5d5426:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_26vbv78r%2Frmt%2Freplicas%2F2&part=all_7_8_1&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 136 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020149cb9 4. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020149637 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002668b3ca 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000002668b87c 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002668d238 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266944e7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 11. DB::ReadBuffer::next() @ 0x0000000008e83ccf 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 14. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a116c03 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1136b9 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 29. ? @ 0x00007f5206343ac3 30. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:45:07.534825 [ 1019 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {069e43ce-7650-4ac3-afc5-602749a91cf3::all_7_8_1}: Code: 86. DB::HTTPException: Received error from remote server http://e2c95b5d5426:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_26vbv78r%2Frmt%2Freplicas%2F2&part=all_7_8_1&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 136 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020149cb9 4. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020149637 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002668b3ca 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000002668b87c 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002668d238 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266944e7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 11. DB::ReadBuffer::next() @ 0x0000000008e83ccf 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 14. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a116c03 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1136b9 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 29. ? @ 0x00007f5206343ac3 30. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:45:08.012006 [ 1050 ] {} test_26vbv78r.rmt1 (069e43ce-7650-4ac3-afc5-602749a91cf3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://e2c95b5d5426:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_26vbv78r%2Frmt%2Freplicas%2F2&part=all_7_8_1&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 136 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020149cb9 4. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020149637 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002668b3ca 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000002668b87c 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002668d238 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266944e7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 11. DB::ReadBuffer::next() @ 0x0000000008e83ccf 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 14. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 21. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 22. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:45:08.142972 [ 1023 ] {} 069e43ce-7650-4ac3-afc5-602749a91cf3::all_7_8_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://e2c95b5d5426:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_26vbv78r%2Frmt%2Freplicas%2F2&part=all_7_8_1&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 136 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020149cb9 4. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020149637 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002668b3ca 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000002668b87c 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002668d238 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266944e7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 11. DB::ReadBuffer::next() @ 0x0000000008e83ccf 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 14. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a116c03 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1136b9 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 29. ? @ 0x00007f5206343ac3 30. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:45:08.149518 [ 1023 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {069e43ce-7650-4ac3-afc5-602749a91cf3::all_7_8_1}: Code: 86. DB::HTTPException: Received error from remote server http://e2c95b5d5426:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_26vbv78r%2Frmt%2Freplicas%2F2&part=all_7_8_1&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 136 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020149cb9 4. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020149637 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002668b3ca 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000002668b87c 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002668d238 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266944e7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 11. DB::ReadBuffer::next() @ 0x0000000008e83ccf 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 14. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a116c03 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1136b9 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 29. ? @ 0x00007f5206343ac3 30. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:45:09.008299 [ 1048 ] {} test_26vbv78r.rmt1 (069e43ce-7650-4ac3-afc5-602749a91cf3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://e2c95b5d5426:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_26vbv78r%2Frmt%2Freplicas%2F2&part=all_7_8_1&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 136 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020149cb9 4. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020149637 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002668b3ca 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000002668b87c 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002668d238 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266944e7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 11. DB::ReadBuffer::next() @ 0x0000000008e83ccf 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 14. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 21. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 22. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:45:10.167079 [ 898 ] {} test_26vbv78r.rmt1 (ReplicatedMergeTreeCleanupThread): Will mark replica 2 as lost, because it has stale log pointer: log-0000000010 2025.06.13 08:45:10.328989 [ 2134 ] {efad11a8-70f9-429d-a6c7-e120977027fe} executeQuery: Code: 475. DB::Exception: Multiple WITH FILL for identical expressions is not supported in ORDER BY. (INVALID_WITH_FILL_EXPRESSION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36972) (comment: 02018_multiple_with_fill_for_the_same_column.sql) (query 1, line 1) (in query: SELECT x, y FROM (SELECT 5 AS x, 'Hello' AS y) ORDER BY x WITH FILL FROM 3 TO 7, y, x WITH FILL FROM 1 TO 10;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:285: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x000000003c0103cf 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr, bool const&, 0>(std::allocator const&, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x000000003c00534e 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl[abi:ne190107] (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x000000003c004765 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f132626 8. ./build_docker/./src/QueryPipeline/Pipe.cpp:632: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f131799 9. ./build_docker/./src/QueryPipeline/QueryPipelineBuilder.cpp:135: DB::QueryPipelineBuilder::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f18a721 10. ./build_docker/./src/Processors/QueryPlan/FillingStep.cpp:50: DB::FillingStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0031f4 11. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049e11 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:45:10.331705 [ 2134 ] {} TCPHandler: Code: 475. DB::Exception: Multiple WITH FILL for identical expressions is not supported in ORDER BY. (INVALID_WITH_FILL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:285: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x000000003c0103cf 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr, bool const&, 0>(std::allocator const&, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x000000003c00534e 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl[abi:ne190107] (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x000000003c004765 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f132626 8. ./build_docker/./src/QueryPipeline/Pipe.cpp:632: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f131799 9. ./build_docker/./src/QueryPipeline/QueryPipelineBuilder.cpp:135: DB::QueryPipelineBuilder::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f18a721 10. ./build_docker/./src/Processors/QueryPlan/FillingStep.cpp:50: DB::FillingStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0031f4 11. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049e11 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:45:14.068721 [ 2136 ] {08a2168f-2495-4a86-8408-364db3a9507a} executeQuery: Code: 43. DB::Exception: First argument of function 'arrayShuffle' must be array: In scope SELECT arrayShuffle(1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37000) (comment: 02523_array_shuffle.sql) (query 68, line 68) (in query: SELECT arrayShuffle(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::FunctionArrayShuffleImpl::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001e2eb23a 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:45:14.071186 [ 2136 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function 'arrayShuffle' must be array: In scope SELECT arrayShuffle(1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::FunctionArrayShuffleImpl::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001e2eb23a 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:45:14.309326 [ 3514 ] {552748d7-5fbe-46b4-8552-f2ba7dfa274a} InterpreterSystemQuery: SYNC REPLICA test_26vbv78r.rmt1 (069e43ce-7650-4ac3-afc5-602749a91cf3): Timed out. 2025.06.13 08:45:14.310204 [ 3514 ] {552748d7-5fbe-46b4-8552-f2ba7dfa274a} executeQuery: Code: 159. DB::Exception: SYNC REPLICA test_26vbv78r.rmt1 (069e43ce-7650-4ac3-afc5-602749a91cf3): command timed out. See the 'receive_timeout' setting. (TIMEOUT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56784) (comment: 02448_clone_replica_lost_part.sql) (query 38, line 69) (in query: -- check that entry was not removed from the queue (part is not lost) system sync replica rmt1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1268: DB::InterpreterSystemQuery::trySyncReplica(std::shared_ptr, DB::SyncReplicaMode, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr) @ 0x0000000033828844 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1284: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x000000003380b8a6 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:763: DB::InterpreterSystemQuery::execute() @ 0x00000000337e4c52 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 08:45:14.311906 [ 3514 ] {} TCPHandler: Code: 159. DB::Exception: SYNC REPLICA test_26vbv78r.rmt1 (069e43ce-7650-4ac3-afc5-602749a91cf3): command timed out. See the 'receive_timeout' setting. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1268: DB::InterpreterSystemQuery::trySyncReplica(std::shared_ptr, DB::SyncReplicaMode, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr) @ 0x0000000033828844 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1284: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x000000003380b8a6 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:763: DB::InterpreterSystemQuery::execute() @ 0x00000000337e4c52 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 08:45:14.365419 [ 2136 ] {3c479662-7473-4be4-bd7f-5be61018e9e4} executeQuery: Code: 43. DB::Exception: Illegal type String of arguments of function arrayShuffle (must be UInt or Int): In scope SELECT arrayShuffle([1], 'a'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37000) (comment: 02523_array_shuffle.sql) (query 69, line 69) (in query: SELECT arrayShuffle([1], 'a');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. auto DB::FunctionArrayShuffleImpl::getReturnTypeImpl(std::vector, std::allocator>> const&) const::'lambda'(auto)::operator()(auto) const @ 0x000000001e2ec6d5 5. DB::FunctionArrayShuffleImpl::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001e2eaf5b 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:45:14.367676 [ 2136 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of arguments of function arrayShuffle (must be UInt or Int): In scope SELECT arrayShuffle([1], 'a'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. auto DB::FunctionArrayShuffleImpl::getReturnTypeImpl(std::vector, std::allocator>> const&) const::'lambda'(auto)::operator()(auto) const @ 0x000000001e2ec6d5 5. DB::FunctionArrayShuffleImpl::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001e2eaf5b 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:45:14.378736 [ 2136 ] {b4f797e9-9935-4505-9242-4a2ccf0edda8} executeQuery: Code: 43. DB::Exception: Illegal type Float64 of arguments of function arrayShuffle (must be UInt or Int): In scope SELECT arrayShuffle([1], 1.1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37000) (comment: 02523_array_shuffle.sql) (query 70, line 70) (in query: SELECT arrayShuffle([1], 1.1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. auto DB::FunctionArrayShuffleImpl::getReturnTypeImpl(std::vector, std::allocator>> const&) const::'lambda'(auto)::operator()(auto) const @ 0x000000001e2ec6d5 5. DB::FunctionArrayShuffleImpl::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001e2eaf5b 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:45:14.382447 [ 2136 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Float64 of arguments of function arrayShuffle (must be UInt or Int): In scope SELECT arrayShuffle([1], 1.1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. auto DB::FunctionArrayShuffleImpl::getReturnTypeImpl(std::vector, std::allocator>> const&) const::'lambda'(auto)::operator()(auto) const @ 0x000000001e2ec6d5 5. DB::FunctionArrayShuffleImpl::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001e2eaf5b 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:45:14.513673 [ 418 ] {} test_26vbv78r.rmt2 (2c6bb706-ccff-40c6-85e9-6c6d7d1e8344): Will mimic 1 2025.06.13 08:45:14.671773 [ 2136 ] {381e50d9-c9aa-4c8d-91ef-f803fabd41e3} executeQuery: Code: 42. DB::Exception: Function 'arrayShuffle' needs from 1 to 2 arguments, passed 3.: In scope SELECT arrayShuffle([1], 51966, 1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37000) (comment: 02523_array_shuffle.sql) (query 71, line 71) (in query: SELECT arrayShuffle([1], 0xcafe, 1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, int const&, unsigned long&&) @ 0x000000001e2ec357 4. DB::FunctionArrayShuffleImpl::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001e2eb4c6 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:45:14.674166 [ 2136 ] {} TCPHandler: Code: 42. DB::Exception: Function 'arrayShuffle' needs from 1 to 2 arguments, passed 3.: In scope SELECT arrayShuffle([1], 51966, 1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, int const&, unsigned long&&) @ 0x000000001e2ec357 4. DB::FunctionArrayShuffleImpl::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001e2eb4c6 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:45:17.242987 [ 528 ] {} RefreshTask: test_6rpenc6i.c: Refresh failed (attempt 1/3): Code: 60. DB::Exception: Unknown table expression identifier 'test_6rpenc6i.src' in scope SELECT * FROM test_6rpenc6i.src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae4366 12. ./build_docker/./src/Storages/StorageMaterializedView.cpp:563: DB::StorageMaterializedView::prepareRefresh(bool, std::shared_ptr, std::optional&) const @ 0x000000003864492b 13. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:584: DB::RefreshTask::executeRefreshUnlocked(bool, int) @ 0x000000003a87bf76 14. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:482: DB::RefreshTask::refreshTask() @ 0x000000003a86cd27 15. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:117: void std::__function::__policy_invoker::__call_impl[abi:ne190107], DB::ASTRefreshStrategy const&, bool, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000003a881c1f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 17. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 18. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:45:17.259760 [ 548 ] {} RefreshTask: test_6rpenc6i.c: Refresh failed (attempt 2/3): Code: 60. DB::Exception: Unknown table expression identifier 'test_6rpenc6i.src' in scope SELECT * FROM test_6rpenc6i.src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae4366 12. ./build_docker/./src/Storages/StorageMaterializedView.cpp:563: DB::StorageMaterializedView::prepareRefresh(bool, std::shared_ptr, std::optional&) const @ 0x000000003864492b 13. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:584: DB::RefreshTask::executeRefreshUnlocked(bool, int) @ 0x000000003a87bf76 14. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:482: DB::RefreshTask::refreshTask() @ 0x000000003a86cd27 15. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:117: void std::__function::__policy_invoker::__call_impl[abi:ne190107], DB::ASTRefreshStrategy const&, bool, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000003a881c1f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 17. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 18. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:45:17.274784 [ 552 ] {} RefreshTask: test_6rpenc6i.c: Refresh failed (attempt 3/3): Code: 60. DB::Exception: Unknown table expression identifier 'test_6rpenc6i.src' in scope SELECT * FROM test_6rpenc6i.src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae4366 12. ./build_docker/./src/Storages/StorageMaterializedView.cpp:563: DB::StorageMaterializedView::prepareRefresh(bool, std::shared_ptr, std::optional&) const @ 0x000000003864492b 13. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:584: DB::RefreshTask::executeRefreshUnlocked(bool, int) @ 0x000000003a87bf76 14. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:482: DB::RefreshTask::refreshTask() @ 0x000000003a86cd27 15. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:117: void std::__function::__policy_invoker::__call_impl[abi:ne190107], DB::ASTRefreshStrategy const&, bool, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000003a881c1f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 17. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 18. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:45:17.935028 [ 1052 ] {} test_26vbv78r.rmt2 (2c6bb706-ccff-40c6-85e9-6c6d7d1e8344): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://e2c95b5d5426:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_26vbv78r%2Frmt%2Freplicas%2F1&part=all_12_12_0&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 136 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020149cb9 4. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020149637 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002668b3ca 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000002668b87c 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002668d238 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266944e7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 11. DB::ReadBuffer::next() @ 0x0000000008e83ccf 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 14. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 21. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 22. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:45:18.032736 [ 603 ] {} RefreshTask: test_6rpenc6i.c: Refresh failed (attempt 1/3): Code: 60. DB::Exception: Unknown table expression identifier 'test_6rpenc6i.src' in scope SELECT * FROM test_6rpenc6i.src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae4366 12. ./build_docker/./src/Storages/StorageMaterializedView.cpp:563: DB::StorageMaterializedView::prepareRefresh(bool, std::shared_ptr, std::optional&) const @ 0x000000003864492b 13. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:584: DB::RefreshTask::executeRefreshUnlocked(bool, int) @ 0x000000003a87bf76 14. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:482: DB::RefreshTask::refreshTask() @ 0x000000003a86cd27 15. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:117: void std::__function::__policy_invoker::__call_impl[abi:ne190107], DB::ASTRefreshStrategy const&, bool, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000003a881c1f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 17. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 18. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:45:18.035698 [ 1043 ] {} test_26vbv78r.rmt2 (2c6bb706-ccff-40c6-85e9-6c6d7d1e8344): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://e2c95b5d5426:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_26vbv78r%2Frmt%2Freplicas%2F1&part=all_12_12_0&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 136 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020149cb9 4. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020149637 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002668b3ca 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000002668b87c 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002668d238 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266944e7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 11. DB::ReadBuffer::next() @ 0x0000000008e83ccf 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 14. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 21. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 22. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:45:18.111939 [ 1039 ] {} test_26vbv78r.rmt2 (2c6bb706-ccff-40c6-85e9-6c6d7d1e8344): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://e2c95b5d5426:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_26vbv78r%2Frmt%2Freplicas%2F1&part=all_12_12_0&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 136 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020149cb9 4. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020149637 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002668b3ca 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000002668b87c 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002668d238 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266944e7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 11. DB::ReadBuffer::next() @ 0x0000000008e83ccf 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 14. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 21. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 22. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:45:18.132678 [ 628 ] {} RefreshTask: test_6rpenc6i.c: Refresh failed (attempt 2/3): Code: 60. DB::Exception: Unknown table expression identifier 'test_6rpenc6i.src' in scope SELECT * FROM test_6rpenc6i.src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae4366 12. ./build_docker/./src/Storages/StorageMaterializedView.cpp:563: DB::StorageMaterializedView::prepareRefresh(bool, std::shared_ptr, std::optional&) const @ 0x000000003864492b 13. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:584: DB::RefreshTask::executeRefreshUnlocked(bool, int) @ 0x000000003a87bf76 14. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:482: DB::RefreshTask::refreshTask() @ 0x000000003a86cd27 15. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:117: void std::__function::__policy_invoker::__call_impl[abi:ne190107], DB::ASTRefreshStrategy const&, bool, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000003a881c1f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 17. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 18. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:45:18.141549 [ 1038 ] {} test_26vbv78r.rmt2 (2c6bb706-ccff-40c6-85e9-6c6d7d1e8344): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://e2c95b5d5426:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_26vbv78r%2Frmt%2Freplicas%2F1&part=all_12_12_0&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 136 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020149cb9 4. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020149637 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002668b3ca 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000002668b87c 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002668d238 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266944e7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 11. DB::ReadBuffer::next() @ 0x0000000008e83ccf 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 14. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 21. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 22. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:45:18.161118 [ 1049 ] {} test_26vbv78r.rmt2 (2c6bb706-ccff-40c6-85e9-6c6d7d1e8344): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://e2c95b5d5426:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_26vbv78r%2Frmt%2Freplicas%2F1&part=all_12_12_0&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 136 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020149cb9 4. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020149637 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002668b3ca 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000002668b87c 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002668d238 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266944e7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 11. DB::ReadBuffer::next() @ 0x0000000008e83ccf 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 14. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 21. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 22. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:45:18.254179 [ 644 ] {} RefreshTask: test_6rpenc6i.c: Refresh failed (attempt 3/3): Code: 60. DB::Exception: Unknown table expression identifier 'test_6rpenc6i.src' in scope SELECT * FROM test_6rpenc6i.src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae4366 12. ./build_docker/./src/Storages/StorageMaterializedView.cpp:563: DB::StorageMaterializedView::prepareRefresh(bool, std::shared_ptr, std::optional&) const @ 0x000000003864492b 13. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:584: DB::RefreshTask::executeRefreshUnlocked(bool, int) @ 0x000000003a87bf76 14. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:482: DB::RefreshTask::refreshTask() @ 0x000000003a86cd27 15. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:117: void std::__function::__policy_invoker::__call_impl[abi:ne190107], DB::ASTRefreshStrategy const&, bool, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000003a881c1f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 17. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 18. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:45:18.906364 [ 1014 ] {} 2c6bb706-ccff-40c6-85e9-6c6d7d1e8344::all_12_12_0_13 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://e2c95b5d5426:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_26vbv78r%2Frmt%2Freplicas%2F1&part=all_12_12_0_13&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 136 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020149cb9 4. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020149637 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002668b3ca 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000002668b87c 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002668d238 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266944e7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 11. DB::ReadBuffer::next() @ 0x0000000008e83ccf 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 14. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a116c03 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1136b9 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 29. ? @ 0x00007f5206343ac3 30. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:45:18.907285 [ 1014 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {2c6bb706-ccff-40c6-85e9-6c6d7d1e8344::all_12_12_0_13}: Code: 86. DB::HTTPException: Received error from remote server http://e2c95b5d5426:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_26vbv78r%2Frmt%2Freplicas%2F1&part=all_12_12_0_13&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 136 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020149cb9 4. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020149637 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002668b3ca 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000002668b87c 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002668d238 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266944e7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 11. DB::ReadBuffer::next() @ 0x0000000008e83ccf 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 14. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a116c03 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1136b9 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 29. ? @ 0x00007f5206343ac3 30. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:45:19.505056 [ 1042 ] {} test_26vbv78r.rmt2 (2c6bb706-ccff-40c6-85e9-6c6d7d1e8344): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://e2c95b5d5426:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_26vbv78r%2Frmt%2Freplicas%2F1&part=all_12_12_0_13&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 136 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020149cb9 4. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020149637 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002668b3ca 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000002668b87c 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002668d238 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266944e7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 11. DB::ReadBuffer::next() @ 0x0000000008e83ccf 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 14. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 21. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 22. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:45:19.568388 [ 4330 ] {c5fc2b66-1ede-4779-97e4-dc4d6661493a} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `y` in scope y >= 20. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58112) (comment: 02703_row_policies_for_database_combination.sh) (query 50, line 74) (in query: SELECT * FROM 02703_unexpected_columns;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000303dd3a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032b465 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308b7e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 10. ./build_docker/./src/Planner/Utils.cpp:473: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x000000003024d32a 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032b66a73 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032b5101c 13. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x0000000032afc62e 14. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:45:19.570291 [ 4330 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `y` in scope y >= 20. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000303dd3a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032b465 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308b7e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 10. ./build_docker/./src/Planner/Utils.cpp:473: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x000000003024d32a 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032b66a73 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032b5101c 13. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x0000000032afc62e 14. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:45:20.174027 [ 1029 ] {} 2c6bb706-ccff-40c6-85e9-6c6d7d1e8344::all_12_12_0_13 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://e2c95b5d5426:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_26vbv78r%2Frmt%2Freplicas%2F1&part=all_12_12_0_13&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 136 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020149cb9 4. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020149637 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002668b3ca 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000002668b87c 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002668d238 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266944e7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 11. DB::ReadBuffer::next() @ 0x0000000008e83ccf 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 14. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a116c03 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1136b9 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 29. ? @ 0x00007f5206343ac3 30. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:45:20.174453 [ 1029 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {2c6bb706-ccff-40c6-85e9-6c6d7d1e8344::all_12_12_0_13}: Code: 86. DB::HTTPException: Received error from remote server http://e2c95b5d5426:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_26vbv78r%2Frmt%2Freplicas%2F1&part=all_12_12_0_13&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 136 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020149cb9 4. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020149637 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002668b3ca 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000002668b87c 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002668d238 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266944e7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 11. DB::ReadBuffer::next() @ 0x0000000008e83ccf 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 14. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a116c03 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1136b9 20. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 29. ? @ 0x00007f5206343ac3 30. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:45:20.577847 [ 3992 ] {d0efc29c-9853-4a4d-a62b-a41f115aa385} executeQuery: Code: 43. DB::Exception: Illegal type UInt16 of argument of function toYYYYMM. Should be Date, Date32, DateTime or DateTime64: While processing toYYYYMM(d). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58218) (comment: 00427_alter_primary_key.sh) (query 1, line 1) (in query: ALTER TABLE alter_00427 MODIFY COLUMN d UInt16), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::FunctionDateOrDateTimeBase::checkArguments(std::vector> const&, bool) const @ 0x000000001a99ba7b 5. DB::FunctionDateOrDateTimeToSomething, DB::ToYYYYMMImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001abf9798 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:329: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x00000000300e3a4d 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:697: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000031b7c892 12. ./src/Interpreters/ActionsMatcher.h:178: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000031ba72b3 13. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1366: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000031b82fba 14. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:756: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000031b7e7b5 15. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000031b5d115 16. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000031ad7246 17. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x0000000031b0f612 18. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000031b1094f 19. ./build_docker/./src/Storages/KeyDescription.cpp:165: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000382932d8 20. ./build_docker/./src/Storages/KeyDescription.cpp:78: DB::KeyDescription::recalculateWithNewAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x00000000382902c7 21. ./build_docker/./src/Storages/AlterCommands.cpp:1280: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000003818b0fc 22. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003981884d 23. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 24. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 08:45:20.584094 [ 3992 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type UInt16 of argument of function toYYYYMM. Should be Date, Date32, DateTime or DateTime64: While processing toYYYYMM(d). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::FunctionDateOrDateTimeBase::checkArguments(std::vector> const&, bool) const @ 0x000000001a99ba7b 5. DB::FunctionDateOrDateTimeToSomething, DB::ToYYYYMMImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001abf9798 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:329: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x00000000300e3a4d 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:697: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000031b7c892 12. ./src/Interpreters/ActionsMatcher.h:178: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000031ba72b3 13. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1366: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000031b82fba 14. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:756: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000031b7e7b5 15. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000031b5d115 16. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000031ad7246 17. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x0000000031b0f612 18. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000031b1094f 19. ./build_docker/./src/Storages/KeyDescription.cpp:165: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000382932d8 20. ./build_docker/./src/Storages/KeyDescription.cpp:78: DB::KeyDescription::recalculateWithNewAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x00000000382902c7 21. ./build_docker/./src/Storages/AlterCommands.cpp:1280: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000003818b0fc 22. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003981884d 23. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 24. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 08:45:21.423541 [ 2135 ] {fd5f008d-0857-4249-9066-7ef82812677b} executeQuery: Code: 117. DB::Exception: Projection non_existing_projection is specified in setting force_optimize_projection_name but not used. (INCORRECT_DATA) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58230) (comment: 02906_force_optimize_projection_name.sql) (query 5, line 20) (in query: SELECT name FROM test GROUP BY name SETTINGS force_optimize_projection_name='non_existing_projection';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:247: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c3bffd8 5. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f95f8 6. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 08:45:21.426352 [ 2135 ] {} TCPHandler: Code: 117. DB::Exception: Projection non_existing_projection is specified in setting force_optimize_projection_name but not used. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:247: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c3bffd8 5. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f95f8 6. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 08:45:21.447003 [ 2135 ] {78fa875b-52ab-47a3-b22b-44502068ebaf} executeQuery: Code: 117. DB::Exception: Projection projection_name is specified in setting force_optimize_projection_name but not used. (INCORRECT_DATA) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58230) (comment: 02906_force_optimize_projection_name.sql) (query 6, line 22) (in query: SELECT name FROM test SETTINGS force_optimize_projection_name='projection_name';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:247: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c3bffd8 5. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f95f8 6. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 08:45:21.449519 [ 2135 ] {} TCPHandler: Code: 117. DB::Exception: Projection projection_name is specified in setting force_optimize_projection_name but not used. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:247: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c3bffd8 5. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f95f8 6. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 08:45:22.253492 [ 901 ] {} test_26vbv78r.rmt2 (ReplicatedMergeTreeCleanupThread): Will mark replica 1 as lost, because it has stale log pointer: log-0000000019 2025.06.13 08:45:23.614882 [ 4015 ] {cb608379-df82-4c94-87c2-80e0ef735a3a} executeQuery: Code: 43. DB::Exception: Illegal type UInt32 of argument of function toTime. Should be Date, Date32, DateTime or DateTime64: While processing toTime(c). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39500) (comment: 00427_alter_primary_key.sh) (query 1, line 1) (in query: ALTER TABLE alter_00427 MODIFY COLUMN c UInt32), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::FunctionDateOrDateTimeBase::checkArguments(std::vector> const&, bool) const @ 0x000000001a99ba7b 5. DB::FunctionDateOrDateTimeToSomething::getReturnTypeImpl(std::vector> const&) const @ 0x000000001abe8264 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:329: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x00000000300e3a4d 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:697: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000031b7c892 12. ./src/Interpreters/ActionsMatcher.h:178: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000031ba72b3 13. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1366: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000031b82fba 14. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:756: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000031b7e7b5 15. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000031b5d115 16. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000031ad7246 17. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x0000000031b0f612 18. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000031b1094f 19. ./build_docker/./src/Storages/KeyDescription.cpp:165: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000382932d8 20. ./build_docker/./src/Storages/KeyDescription.cpp:78: DB::KeyDescription::recalculateWithNewAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x00000000382902c7 21. ./build_docker/./src/Storages/AlterCommands.cpp:1266: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000003818ac3a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003981884d 23. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 24. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 08:45:23.620096 [ 4015 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type UInt32 of argument of function toTime. Should be Date, Date32, DateTime or DateTime64: While processing toTime(c). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::FunctionDateOrDateTimeBase::checkArguments(std::vector> const&, bool) const @ 0x000000001a99ba7b 5. DB::FunctionDateOrDateTimeToSomething::getReturnTypeImpl(std::vector> const&) const @ 0x000000001abe8264 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:329: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x00000000300e3a4d 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:697: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000031b7c892 12. ./src/Interpreters/ActionsMatcher.h:178: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000031ba72b3 13. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1366: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000031b82fba 14. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:756: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000031b7e7b5 15. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000031b5d115 16. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000031ad7246 17. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x0000000031b0f612 18. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000031b1094f 19. ./build_docker/./src/Storages/KeyDescription.cpp:165: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000382932d8 20. ./build_docker/./src/Storages/KeyDescription.cpp:78: DB::KeyDescription::recalculateWithNewAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x00000000382902c7 21. ./build_docker/./src/Storages/AlterCommands.cpp:1266: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000003818ac3a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003981884d 23. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 24. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 08:45:25.576053 [ 3514 ] {2226cc8b-17ae-4d26-85c6-d03bcc98dac8} InterpreterSystemQuery: SYNC REPLICA test_26vbv78r.rmt2 (2c6bb706-ccff-40c6-85e9-6c6d7d1e8344): Timed out. 2025.06.13 08:45:25.576971 [ 3514 ] {2226cc8b-17ae-4d26-85c6-d03bcc98dac8} executeQuery: Code: 159. DB::Exception: SYNC REPLICA test_26vbv78r.rmt2 (2c6bb706-ccff-40c6-85e9-6c6d7d1e8344): command timed out. See the 'receive_timeout' setting. (TIMEOUT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56784) (comment: 02448_clone_replica_lost_part.sql) (query 60, line 105) (in query: system sync replica rmt2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1268: DB::InterpreterSystemQuery::trySyncReplica(std::shared_ptr, DB::SyncReplicaMode, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr) @ 0x0000000033828844 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1284: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x000000003380b8a6 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:763: DB::InterpreterSystemQuery::execute() @ 0x00000000337e4c52 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 08:45:25.578650 [ 3514 ] {} TCPHandler: Code: 159. DB::Exception: SYNC REPLICA test_26vbv78r.rmt2 (2c6bb706-ccff-40c6-85e9-6c6d7d1e8344): command timed out. See the 'receive_timeout' setting. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1268: DB::InterpreterSystemQuery::trySyncReplica(std::shared_ptr, DB::SyncReplicaMode, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr) @ 0x0000000033828844 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1284: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x000000003380b8a6 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:763: DB::InterpreterSystemQuery::execute() @ 0x00000000337e4c52 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 08:45:25.782654 [ 552 ] {} test_26vbv78r.rmt1 (069e43ce-7650-4ac3-afc5-602749a91cf3): Will mimic 2 2025.06.13 08:45:25.787698 [ 552 ] {} test_26vbv78r.rmt1 (069e43ce-7650-4ac3-afc5-602749a91cf3): Source replica does not have part all_9_9_0. Removing it from ZooKeeper. 2025.06.13 08:45:25.787878 [ 552 ] {} test_26vbv78r.rmt1 (069e43ce-7650-4ac3-afc5-602749a91cf3): Source replica does not have part all_10_10_0. Removing it from ZooKeeper. 2025.06.13 08:45:25.787941 [ 552 ] {} test_26vbv78r.rmt1 (069e43ce-7650-4ac3-afc5-602749a91cf3): Source replica does not have part all_11_11_0. Removing it from ZooKeeper. 2025.06.13 08:45:25.787988 [ 552 ] {} test_26vbv78r.rmt1 (069e43ce-7650-4ac3-afc5-602749a91cf3): Source replica does not have part all_7_8_1. Removing it from ZooKeeper. 2025.06.13 08:45:25.837534 [ 404 ] {72fffd3d-009d-44a2-94a1-75f587e89805} executeQuery: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 100.00 thousand, current rows: 181.35 thousand: While executing NumbersRange. (TOO_MANY_ROWS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39546) (comment: 01231_log_queries_min_type.sql) (query 11, line 18) (in query: select '01231_log_queries_min_type/EXCEPTION_WHILE_PROCESSING', max(number) from system.numbers limit 1e6;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f24bc97 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f24776e 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002f1bbd72 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e6ab7 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:45:25.842276 [ 404 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 100.00 thousand, current rows: 181.35 thousand: While executing NumbersRange. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f24bc97 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f24776e 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002f1bbd72 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e6ab7 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:45:26.290895 [ 404 ] {37086325-39a5-486f-9bc3-4e52773c3069} executeQuery: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 100.00 thousand, current rows: 181.35 thousand: While executing NumbersRange. (TOO_MANY_ROWS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39546) (comment: 01231_log_queries_min_type.sql) (query 16, line 26) (in query: select '01231_log_queries_min_type w/ Settings/EXCEPTION_WHILE_PROCESSING', max(number) from system.numbers limit 1e6;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f24bc97 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f24776e 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002f1bbd72 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e6ab7 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:45:26.295703 [ 404 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 100.00 thousand, current rows: 181.35 thousand: While executing NumbersRange. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f24bc97 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f24776e 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002f1bbd72 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e6ab7 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:45:33.187435 [ 1015 ] {246a0268-0202-4864-b8bf-9d19400e3dd5::all_37_72_2} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x000000003968bba7 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:921: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::finalize() const @ 0x00000000396c3c9c 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:882: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000396c3902 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000396bdc00 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000396d5401 9. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a471407 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:45:33.187428 [ 1025 ] {246a0268-0202-4864-b8bf-9d19400e3dd5::all_73_101_2} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x000000003968bba7 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:921: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::finalize() const @ 0x00000000396c3c9c 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:882: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000396c3902 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000396bdc00 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000396d5401 9. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a471407 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:45:33.688393 [ 516 ] {} test_26vbv78r.rmt2 (ReplicatedMergeTreeCleanupThread): Will mark replica 1 as lost, because it has stale log pointer: log-0000000026 2025.06.13 08:45:35.353306 [ 3992 ] {6aa692f4-1cf6-4938-bb8c-37b4bc42aabb} executeQuery: Code: 60. DB::Exception: Table `test_ajn6vqd1`.`t1` doesn't exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59806) (comment: 01185_create_or_replace_table.sql) (query 2, line 5) (in query: replace table t1 (n UInt64, s String) engine=MergeTree order by n;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x000000002f9dc4a8 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:310: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x000000002f80912d 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a037d4 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2161: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000003290fe86 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000032902089 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:45:35.355354 [ 3992 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_ajn6vqd1`.`t1` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x000000002f9dc4a8 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:310: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x000000002f80912d 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a037d4 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2161: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000003290fe86 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000032902089 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:45:37.234314 [ 851 ] {} test_26vbv78r.rmt1 (069e43ce-7650-4ac3-afc5-602749a91cf3): Will mimic 2 2025.06.13 08:45:37.239227 [ 851 ] {} test_26vbv78r.rmt1 (069e43ce-7650-4ac3-afc5-602749a91cf3): Source replica does not have part all_18_18_0. Removing it from ZooKeeper. 2025.06.13 08:45:37.239335 [ 851 ] {} test_26vbv78r.rmt1 (069e43ce-7650-4ac3-afc5-602749a91cf3): Source replica does not have part all_17_17_0. Removing it from ZooKeeper. 2025.06.13 08:45:37.239397 [ 851 ] {} test_26vbv78r.rmt1 (069e43ce-7650-4ac3-afc5-602749a91cf3): Source replica does not have part all_19_19_0. Removing it from ZooKeeper. 2025.06.13 08:45:37.239456 [ 851 ] {} test_26vbv78r.rmt1 (069e43ce-7650-4ac3-afc5-602749a91cf3): Source replica does not have part all_12_12_0_13. Removing it from ZooKeeper. 2025.06.13 08:45:37.239513 [ 851 ] {} test_26vbv78r.rmt1 (069e43ce-7650-4ac3-afc5-602749a91cf3): Source replica does not have part all_7_8_1_13. Removing it from ZooKeeper. 2025.06.13 08:45:37.239568 [ 851 ] {} test_26vbv78r.rmt1 (069e43ce-7650-4ac3-afc5-602749a91cf3): Source replica does not have part all_9_9_0_13. Removing it from ZooKeeper. 2025.06.13 08:45:37.239633 [ 851 ] {} test_26vbv78r.rmt1 (069e43ce-7650-4ac3-afc5-602749a91cf3): Source replica does not have part all_10_10_0_13. Removing it from ZooKeeper. 2025.06.13 08:45:37.239708 [ 851 ] {} test_26vbv78r.rmt1 (069e43ce-7650-4ac3-afc5-602749a91cf3): Source replica does not have part all_15_15_0. Removing it from ZooKeeper. 2025.06.13 08:45:37.239769 [ 851 ] {} test_26vbv78r.rmt1 (069e43ce-7650-4ac3-afc5-602749a91cf3): Source replica does not have part all_14_14_0. Removing it from ZooKeeper. 2025.06.13 08:45:37.239829 [ 851 ] {} test_26vbv78r.rmt1 (069e43ce-7650-4ac3-afc5-602749a91cf3): Source replica does not have part all_16_16_0. Removing it from ZooKeeper. 2025.06.13 08:45:37.239885 [ 851 ] {} test_26vbv78r.rmt1 (069e43ce-7650-4ac3-afc5-602749a91cf3): Source replica does not have part all_11_11_0_13. Removing it from ZooKeeper. 2025.06.13 08:45:37.260522 [ 851 ] {} test_26vbv78r.rmt1 (069e43ce-7650-4ac3-afc5-602749a91cf3): Source replica does not have part all_18_18_0. Removing it from working set. 2025.06.13 08:45:37.260841 [ 851 ] {} test_26vbv78r.rmt1 (069e43ce-7650-4ac3-afc5-602749a91cf3): Source replica does not have part all_19_19_0. Removing it from working set. 2025.06.13 08:45:37.324287 [ 1038 ] {} test_26vbv78r.rmt1 (069e43ce-7650-4ac3-afc5-602749a91cf3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://e2c95b5d5426:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_26vbv78r%2Frmt%2Freplicas%2F2&part=all_18_22_1&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 136 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020149cb9 4. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020149637 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002668b3ca 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000002668b87c 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002668d238 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266944e7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 11. DB::ReadBuffer::next() @ 0x0000000008e83ccf 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 14. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 21. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 22. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:45:37.326601 [ 1043 ] {} test_26vbv78r.rmt1 (069e43ce-7650-4ac3-afc5-602749a91cf3): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://e2c95b5d5426:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_26vbv78r%2Frmt%2Freplicas%2F2&part=all_23_23_0&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 136 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020149cb9 4. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020149637 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002668b3ca 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000002668b87c 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002668d238 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266944e7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 11. DB::ReadBuffer::next() @ 0x0000000008e83ccf 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 14. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 21. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 22. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:45:40.596090 [ 2136 ] {deb22dab-160b-4888-82b8-e7a466dc9f85} executeQuery: Code: 36. DB::Exception: Table test_6rpenc6i.dest is already a target of another refreshable materialized view: test_6rpenc6i.h. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60528) (comment: 02932_refreshable_materialized_views_2.sh) (query 6, line 7) (in query: create materialized view hh refresh every 2 second to dest as select x from src;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Storages/StorageMaterializedView.cpp:207: DB::StorageMaterializedView::StorageMaterializedView(DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel, String const&) @ 0x0000000038633df8 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&, 0>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&) @ 0x000000003865af60 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000038655231 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:45:40.604790 [ 2136 ] {} TCPHandler: Code: 36. DB::Exception: Table test_6rpenc6i.dest is already a target of another refreshable materialized view: test_6rpenc6i.h. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Storages/StorageMaterializedView.cpp:207: DB::StorageMaterializedView::StorageMaterializedView(DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel, String const&) @ 0x0000000038633df8 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&, 0>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&) @ 0x000000003865af60 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000038655231 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:45:43.718202 [ 2141 ] {427ef462-aa19-4659-baa9-4f5b0b92e693} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatDateTime doesn't match: passed 0, should be 2 or 3: In scope SELECT formatDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52198) (comment: 00718_format_datetime.sql) (query 2, line 3) (in query: SELECT formatDateTime();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000008baf06d 4. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ec1d7d5 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:45:43.729706 [ 2141 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatDateTime doesn't match: passed 0, should be 2 or 3: In scope SELECT formatDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000008baf06d 4. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ec1d7d5 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:45:44.276439 [ 2141 ] {d0698738-da3b-4ce9-b81a-ab6abc1860ea} executeQuery: Code: 43. DB::Exception: Illegal type String of first argument of function formatDateTime. Should be a date or a date with time: In scope SELECT formatDateTime('not a datetime', 'IGNORED'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52198) (comment: 00718_format_datetime.sql) (query 3, line 4) (in query: SELECT formatDateTime('not a datetime', 'IGNORED');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ec1df2c 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:45:44.291034 [ 2141 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of first argument of function formatDateTime. Should be a date or a date with time: In scope SELECT formatDateTime('not a datetime', 'IGNORED'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ec1df2c 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:45:44.938021 [ 2141 ] {40352dab-2b67-41e3-b9e9-e82d5103fa63} executeQuery: Code: 43. DB::Exception: Illegal type DateTime of second argument of function formatDateTime. Must be String.: In scope SELECT formatDateTime(now(), now()). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52198) (comment: 00718_format_datetime.sql) (query 4, line 5) (in query: SELECT formatDateTime(now(), now());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ec1da3f 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:45:44.945400 [ 2141 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type DateTime of second argument of function formatDateTime. Must be String.: In scope SELECT formatDateTime(now(), now()). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ec1da3f 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:45:45.078694 [ 415 ] {} RefreshTask: test_6rpenc6i.h2: Refresh failed (attempt 1/11): Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(modulo(__table1.x, 2_UInt8), 0_UInt8) :: 2) -> throwIf(equals(modulo(__table1.x, 2_UInt8), 0_UInt8)) UInt8 : 3'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:629: DB::RefreshTask::executeRefreshUnlocked(bool, int) @ 0x000000003a87cde0 8. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:482: DB::RefreshTask::refreshTask() @ 0x000000003a86cd27 9. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:117: void std::__function::__policy_invoker::__call_impl[abi:ne190107], DB::ASTRefreshStrategy const&, bool, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000003a881c1f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:45:45.217628 [ 440 ] {} RefreshTask: test_6rpenc6i.h2: Refresh failed (attempt 2/11): Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(modulo(__table1.x, 2_UInt8), 0_UInt8) :: 2) -> throwIf(equals(modulo(__table1.x, 2_UInt8), 0_UInt8)) UInt8 : 3'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:629: DB::RefreshTask::executeRefreshUnlocked(bool, int) @ 0x000000003a87cde0 8. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:482: DB::RefreshTask::refreshTask() @ 0x000000003a86cd27 9. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:117: void std::__function::__policy_invoker::__call_impl[abi:ne190107], DB::ASTRefreshStrategy const&, bool, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000003a881c1f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:45:45.297735 [ 440 ] {} RefreshTask: test_6rpenc6i.h2: Refresh failed (attempt 3/11): Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(modulo(__table1.x, 2_UInt8), 0_UInt8) :: 2) -> throwIf(equals(modulo(__table1.x, 2_UInt8), 0_UInt8)) UInt8 : 3'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:629: DB::RefreshTask::executeRefreshUnlocked(bool, int) @ 0x000000003a87cde0 8. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:482: DB::RefreshTask::refreshTask() @ 0x000000003a86cd27 9. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:117: void std::__function::__policy_invoker::__call_impl[abi:ne190107], DB::ASTRefreshStrategy const&, bool, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000003a881c1f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:45:45.491669 [ 468 ] {} RefreshTask: test_6rpenc6i.h2: Refresh failed (attempt 4/11): Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(modulo(__table1.x, 2_UInt8), 0_UInt8) :: 2) -> throwIf(equals(modulo(__table1.x, 2_UInt8), 0_UInt8)) UInt8 : 3'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:629: DB::RefreshTask::executeRefreshUnlocked(bool, int) @ 0x000000003a87cde0 8. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:482: DB::RefreshTask::refreshTask() @ 0x000000003a86cd27 9. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:117: void std::__function::__policy_invoker::__call_impl[abi:ne190107], DB::ASTRefreshStrategy const&, bool, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000003a881c1f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:45:45.497527 [ 2141 ] {055523e7-8572-4c29-9fb9-54faaf5dde19} executeQuery: Code: 43. DB::Exception: Illegal type DateTime of third argument of function formatDateTime. Must be String.: In scope SELECT formatDateTime(now(), 'good format pattern', now()). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52198) (comment: 00718_format_datetime.sql) (query 5, line 6) (in query: SELECT formatDateTime(now(), 'good format pattern', now());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ec1dcac 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:45:45.500188 [ 2141 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type DateTime of third argument of function formatDateTime. Must be String.: In scope SELECT formatDateTime(now(), 'good format pattern', now()). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ec1dcac 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:45:45.867841 [ 723 ] {} RefreshTask: test_6rpenc6i.h2: Refresh failed (attempt 5/11): Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(modulo(__table1.x, 2_UInt8), 0_UInt8) :: 2) -> throwIf(equals(modulo(__table1.x, 2_UInt8), 0_UInt8)) UInt8 : 3'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:629: DB::RefreshTask::executeRefreshUnlocked(bool, int) @ 0x000000003a87cde0 8. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:482: DB::RefreshTask::refreshTask() @ 0x000000003a86cd27 9. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:117: void std::__function::__policy_invoker::__call_impl[abi:ne190107], DB::ASTRefreshStrategy const&, bool, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000003a881c1f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:45:46.114131 [ 2141 ] {126e7a29-83a2-42dd-8321-afdf76d65114} executeQuery: Code: 36. DB::Exception: '%' must not be the last character in the format string, use '%%' instead: In scope SELECT formatDateTime(now(), 'unescaped %'). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52198) (comment: 00718_format_datetime.sql) (query 6, line 7) (in query: SELECT formatDateTime(now(), 'unescaped %');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::throwLastCharacterIsPercentException() @ 0x000000000ec1e9ec 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::containsOnlyFixedWidthMySQLFormatters(std::basic_string_view>, bool, bool) @ 0x000000000ec1e5e3 6. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ec14cba 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 2025.06.13 08:45:46.116770 [ 2141 ] {} TCPHandler: Code: 36. DB::Exception: '%' must not be the last character in the format string, use '%%' instead: In scope SELECT formatDateTime(now(), 'unescaped %'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::throwLastCharacterIsPercentException() @ 0x000000000ec1e9ec 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::containsOnlyFixedWidthMySQLFormatters(std::basic_string_view>, bool, bool) @ 0x000000000ec1e5e3 6. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ec14cba 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 2025.06.13 08:45:46.139870 [ 2133 ] {09783932-2e0c-45b4-9ec7-071c0a098d42} executeQuery: Code: 730. DB::Exception: Refresh failed: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(modulo(__table1.x, 2_UInt8), 0_UInt8) :: 2) -> throwIf(equals(modulo(__table1.x, 2_UInt8), 0_UInt8)) UInt8 : 3'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:629: DB::RefreshTask::executeRefreshUnlocked(bool, int) @ 0x000000003a87cde0 8. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:482: DB::RefreshTask::refreshTask() @ 0x000000003a86cd27 9. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:117: void std::__function::__policy_invoker::__call_impl[abi:ne190107], DB::ASTRefreshStrategy const&, bool, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000003a881c1f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)). (REFRESH_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52542) (comment: 02932_refreshable_materialized_views_2.sh) (query 1, line 1) (in query: system wait view h2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:286: DB::RefreshTask::wait()::$_0::operator()() const @ 0x000000003a86a6a8 5. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:296: DB::RefreshTask::wait() @ 0x000000003a869078 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:746: DB::InterpreterSystemQuery::execute() @ 0x00000000337e4e85 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 08:45:46.142341 [ 2133 ] {} TCPHandler: Code: 730. DB::Exception: Refresh failed: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(modulo(__table1.x, 2_UInt8), 0_UInt8) :: 2) -> throwIf(equals(modulo(__table1.x, 2_UInt8), 0_UInt8)) UInt8 : 3'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:629: DB::RefreshTask::executeRefreshUnlocked(bool, int) @ 0x000000003a87cde0 8. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:482: DB::RefreshTask::refreshTask() @ 0x000000003a86cd27 9. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:117: void std::__function::__policy_invoker::__call_impl[abi:ne190107], DB::ASTRefreshStrategy const&, bool, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000003a881c1f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)). (REFRESH_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:286: DB::RefreshTask::wait()::$_0::operator()() const @ 0x000000003a86a6a8 5. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:296: DB::RefreshTask::wait() @ 0x000000003a869078 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:746: DB::InterpreterSystemQuery::execute() @ 0x00000000337e4e85 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 08:45:46.432876 [ 2141 ] {c739f41a-69ab-45f8-9b0f-1f06306f7ab8} executeQuery: Code: 48. DB::Exception: format is not supported for WEEK (Sun-Sat): In scope SELECT formatDateTime(toDateTime('2018-01-02 22:33:44'), '%U'). (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52198) (comment: 00718_format_datetime.sql) (query 7, line 8) (in query: SELECT formatDateTime(toDateTime('2018-01-02 22:33:44'), '%U');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. unsigned long DB::(anonymous namespace)::FunctionFormatDateTimeImpl::parseMySQLFormat(String const&, std::vector::Instruction, std::allocator::Instruction>>&, unsigned int, bool, String&) const @ 0x000000000ec34713 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ec14d80 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 2025.06.13 08:45:46.434812 [ 2141 ] {} TCPHandler: Code: 48. DB::Exception: format is not supported for WEEK (Sun-Sat): In scope SELECT formatDateTime(toDateTime('2018-01-02 22:33:44'), '%U'). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. unsigned long DB::(anonymous namespace)::FunctionFormatDateTimeImpl::parseMySQLFormat(String const&, std::vector::Instruction, std::allocator::Instruction>>&, unsigned int, bool, String&) const @ 0x000000000ec34713 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ec14d80 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 2025.06.13 08:45:46.678318 [ 876 ] {} RefreshTask: test_6rpenc6i.h2: Refresh failed (attempt 6/11): Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(modulo(__table1.x, 2_UInt8), 0_UInt8) :: 2) -> throwIf(equals(modulo(__table1.x, 2_UInt8), 0_UInt8)) UInt8 : 3'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:629: DB::RefreshTask::executeRefreshUnlocked(bool, int) @ 0x000000003a87cde0 8. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:482: DB::RefreshTask::refreshTask() @ 0x000000003a86cd27 9. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:117: void std::__function::__policy_invoker::__call_impl[abi:ne190107], DB::ASTRefreshStrategy const&, bool, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000003a881c1f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:45:46.997364 [ 2141 ] {307fad74-5c39-4b41-960d-baa94408caf7} executeQuery: Code: 48. DB::Exception: format is not supported for WEEK (Mon-Sun): In scope SELECT formatDateTime(toDateTime('2018-01-02 22:33:44'), '%v'). (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52198) (comment: 00718_format_datetime.sql) (query 8, line 9) (in query: SELECT formatDateTime(toDateTime('2018-01-02 22:33:44'), '%v');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. unsigned long DB::(anonymous namespace)::FunctionFormatDateTimeImpl::parseMySQLFormat(String const&, std::vector::Instruction, std::allocator::Instruction>>&, unsigned int, bool, String&) const @ 0x000000000ec3495f 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ec14d80 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 2025.06.13 08:45:47.009403 [ 2141 ] {} TCPHandler: Code: 48. DB::Exception: format is not supported for WEEK (Mon-Sun): In scope SELECT formatDateTime(toDateTime('2018-01-02 22:33:44'), '%v'). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. unsigned long DB::(anonymous namespace)::FunctionFormatDateTimeImpl::parseMySQLFormat(String const&, std::vector::Instruction, std::allocator::Instruction>>&, unsigned int, bool, String&) const @ 0x000000000ec3495f 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ec14d80 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 2025.06.13 08:45:47.611058 [ 2141 ] {f12d9cd8-a923-4e50-bc12-8051f931f745} executeQuery: Code: 48. DB::Exception: format is not supported for YEAR for week (Mon-Sun): In scope SELECT formatDateTime(toDateTime('2018-01-02 22:33:44'), '%x'). (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52198) (comment: 00718_format_datetime.sql) (query 9, line 10) (in query: SELECT formatDateTime(toDateTime('2018-01-02 22:33:44'), '%x');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. unsigned long DB::(anonymous namespace)::FunctionFormatDateTimeImpl::parseMySQLFormat(String const&, std::vector::Instruction, std::allocator::Instruction>>&, unsigned int, bool, String&) const @ 0x000000000ec34a8c 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ec14d80 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 2025.06.13 08:45:47.615999 [ 2141 ] {} TCPHandler: Code: 48. DB::Exception: format is not supported for YEAR for week (Mon-Sun): In scope SELECT formatDateTime(toDateTime('2018-01-02 22:33:44'), '%x'). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. unsigned long DB::(anonymous namespace)::FunctionFormatDateTimeImpl::parseMySQLFormat(String const&, std::vector::Instruction, std::allocator::Instruction>>&, unsigned int, bool, String&) const @ 0x000000000ec34a8c 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ec14d80 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 2025.06.13 08:45:48.233805 [ 2141 ] {13f50de2-778e-49ae-9e32-1b0436004db0} executeQuery: Code: 48. DB::Exception: format is not supported for YEAR for week (Sun-Sat): In scope SELECT formatDateTime(toDateTime('2018-01-02 22:33:44'), '%X'). (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52198) (comment: 00718_format_datetime.sql) (query 10, line 11) (in query: SELECT formatDateTime(toDateTime('2018-01-02 22:33:44'), '%X');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. unsigned long DB::(anonymous namespace)::FunctionFormatDateTimeImpl::parseMySQLFormat(String const&, std::vector::Instruction, std::allocator::Instruction>>&, unsigned int, bool, String&) const @ 0x000000000ec34839 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ec14d80 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 2025.06.13 08:45:48.258867 [ 2141 ] {} TCPHandler: Code: 48. DB::Exception: format is not supported for YEAR for week (Sun-Sat): In scope SELECT formatDateTime(toDateTime('2018-01-02 22:33:44'), '%X'). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. unsigned long DB::(anonymous namespace)::FunctionFormatDateTimeImpl::parseMySQLFormat(String const&, std::vector::Instruction, std::allocator::Instruction>>&, unsigned int, bool, String&) const @ 0x000000000ec34839 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ec14d80 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 2025.06.13 08:45:57.957251 [ 5281 ] {test_r6gsqv1xhello} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:60382) (comment: 00600_replace_running_query.sh) (in query: SELECT 1, count() FROM system.numbers), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032e79999 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032e796c3 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032e7ac23 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b0aef87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae681 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:45:57.962295 [ 5281 ] {test_r6gsqv1xhello} DynamicQueryHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032e79999 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032e796c3 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032e7ac23 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b0aef87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae681 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:45:58.022842 [ 2136 ] {f4240e31-46a7-4c88-845f-723a10724457} executeQuery: Code: 48. DB::Exception: Adding or removing APPEND is not supported. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37750) (comment: 02932_refreshable_materialized_views_2.sh) (query 1, line 2) (in query: alter table k modify refresh every 10 year;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:203: DB::RefreshTask::checkAlterIsPossible(DB::ASTRefreshStrategy const&) @ 0x000000003a866a37 5. ./build_docker/./src/Storages/StorageMaterializedView.cpp:677: DB::StorageMaterializedView::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003864c402 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 08:45:58.025141 [ 2136 ] {} TCPHandler: Code: 48. DB::Exception: Adding or removing APPEND is not supported. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:203: DB::RefreshTask::checkAlterIsPossible(DB::ASTRefreshStrategy const&) @ 0x000000003a866a37 5. ./build_docker/./src/Storages/StorageMaterializedView.cpp:677: DB::StorageMaterializedView::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003864c402 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 08:45:59.237895 [ 2136 ] {test_r6gsqv1x42} executeQuery: Code: 216. DB::Exception: Query with id = test_r6gsqv1x42 is already running by user u_00600test_r6gsqv1x. (QUERY_WITH_SAME_ID_IS_ALREADY_RUNNING) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37826) (comment: 00600_replace_running_query.sh) (query 1, line 1) (in query: SELECT 43), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&) @ 0x000000001ffa1a4d 4. ./build_docker/./src/Interpreters/ProcessList.cpp:240: DB::ProcessList::insert(String const&, unsigned long, DB::IAST const*, std::shared_ptr, unsigned long) @ 0x0000000032e6e8fe 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1180: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x00000000337295a3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 7. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:45:59.240502 [ 2136 ] {} TCPHandler: Code: 216. DB::Exception: Query with id = test_r6gsqv1x42 is already running by user u_00600test_r6gsqv1x. (QUERY_WITH_SAME_ID_IS_ALREADY_RUNNING), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&) @ 0x000000001ffa1a4d 4. ./build_docker/./src/Interpreters/ProcessList.cpp:240: DB::ProcessList::insert(String const&, unsigned long, DB::IAST const*, std::shared_ptr, unsigned long) @ 0x0000000032e6e8fe 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1180: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x00000000337295a3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 7. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:45:59.499157 [ 4332 ] {test_r6gsqv1x42} executeQuery: Code: 216. DB::Exception: Query with id = test_r6gsqv1x42 is already running by user u_00600test_r6gsqv1x. (QUERY_WITH_SAME_ID_IS_ALREADY_RUNNING) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:60432) (comment: 00600_replace_running_query.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&) @ 0x000000001ffa1a4d 4. ./build_docker/./src/Interpreters/ProcessList.cpp:240: DB::ProcessList::insert(String const&, unsigned long, DB::IAST const*, std::shared_ptr, unsigned long) @ 0x0000000032e6e8fe 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1180: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x00000000337295a3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 7. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:45:59.501751 [ 4332 ] {test_r6gsqv1x42} DynamicQueryHandler: Code: 216. DB::Exception: Query with id = test_r6gsqv1x42 is already running by user u_00600test_r6gsqv1x. (QUERY_WITH_SAME_ID_IS_ALREADY_RUNNING), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&) @ 0x000000001ffa1a4d 4. ./build_docker/./src/Interpreters/ProcessList.cpp:240: DB::ProcessList::insert(String const&, unsigned long, DB::IAST const*, std::shared_ptr, unsigned long) @ 0x0000000032e6e8fe 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1180: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x00000000337295a3 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 7. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:45:59.690703 [ 4466 ] {test_r6gsqv1x42} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37764) (query 1, line 1) (in query: SELECT 2, count() FROM system.numbers), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032e79999 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032e796c3 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032e7ac23 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b0aef87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae681 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 08:45:59.694569 [ 4466 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032e79999 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032e796c3 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032e7ac23 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b0aef87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae681 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:46:00.923771 [ 4015 ] {fd0397d2-8a2e-4de0-a538-f9a428fe8ba2} executeQuery: Code: 42. DB::Exception: ORDER BY or PRIMARY KEY clause is missing. Consider using extended storage definition syntax with ORDER BY or PRIMARY KEY clause. With deprecated old syntax (highly not recommended) storage MergeTree requires 3 to 4 parameters: name of column with date, [sampling element of primary key], primary key expression, index granularity Syntax for the MergeTree table engine: CREATE TABLE [IF NOT EXISTS] [db.]table_name [ON CLUSTER cluster] ( name1 [type1] [DEFAULT|MATERIALIZED|ALIAS expr1] [TTL expr1], name2 [type2] [DEFAULT|MATERIALIZED|ALIAS expr2] [TTL expr2], ... INDEX index_name1 expr1 TYPE type1(...) [GRANULARITY value1], INDEX index_name2 expr2 TYPE type2(...) [GRANULARITY value2] ) ENGINE = MergeTree() ORDER BY expr [PARTITION BY expr] [PRIMARY KEY expr] [SAMPLE BY expr] [TTL expr [DELETE|TO DISK 'xxx'|TO VOLUME 'xxx'], ...] [SETTINGS name=value, ...] [COMMENT 'comment'] See details in documentation: https://clickhouse.com/docs/engines/table-engines/mergetree-family/mergetree/. Other engines of the family support different syntax, see details in the corresponding documentation topics. If you use the Replicated version of engines, see https://clickhouse.com/docs/engines/table-engines/mergetree-family/replication/. . (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37920) (comment: 02932_refreshable_materialized_views_2.sh) (query 1, line 2) (in query: create materialized view n refresh every 1 second (x Int64) engine MergeTree as select 1 as x from numbers(2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&, char const* const&) @ 0x000000003a38a377 4. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:502: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a3837a2 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 10. ./build_docker/./src/Storages/StorageMaterializedView.cpp:297: DB::StorageMaterializedView::StorageMaterializedView(DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel, String const&) @ 0x00000000386319a8 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&, 0>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&) @ 0x000000003865af60 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000038655231 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:46:00.926803 [ 4015 ] {} TCPHandler: Code: 42. DB::Exception: ORDER BY or PRIMARY KEY clause is missing. Consider using extended storage definition syntax with ORDER BY or PRIMARY KEY clause. With deprecated old syntax (highly not recommended) storage MergeTree requires 3 to 4 parameters: name of column with date, [sampling element of primary key], primary key expression, index granularity Syntax for the MergeTree table engine: CREATE TABLE [IF NOT EXISTS] [db.]table_name [ON CLUSTER cluster] ( name1 [type1] [DEFAULT|MATERIALIZED|ALIAS expr1] [TTL expr1], name2 [type2] [DEFAULT|MATERIALIZED|ALIAS expr2] [TTL expr2], ... INDEX index_name1 expr1 TYPE type1(...) [GRANULARITY value1], INDEX index_name2 expr2 TYPE type2(...) [GRANULARITY value2] ) ENGINE = MergeTree() ORDER BY expr [PARTITION BY expr] [PRIMARY KEY expr] [SAMPLE BY expr] [TTL expr [DELETE|TO DISK 'xxx'|TO VOLUME 'xxx'], ...] [SETTINGS name=value, ...] [COMMENT 'comment'] See details in documentation: https://clickhouse.com/docs/engines/table-engines/mergetree-family/mergetree/. Other engines of the family support different syntax, see details in the corresponding documentation topics. If you use the Replicated version of engines, see https://clickhouse.com/docs/engines/table-engines/mergetree-family/replication/. . (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&, char const* const&) @ 0x000000003a38a377 4. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:502: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a3837a2 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 10. ./build_docker/./src/Storages/StorageMaterializedView.cpp:297: DB::StorageMaterializedView::StorageMaterializedView(DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel, String const&) @ 0x00000000386319a8 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&, 0>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&) @ 0x000000003865af60 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000038655231 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:46:01.593358 [ 2085 ] {test_r6gsqv1x42} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37966) (comment: 00600_replace_running_query.sh) (query 1, line 1) (in query: SELECT 3, count() FROM system.numbers), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032e79999 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032e796c3 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032e7ac23 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b0aef87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae681 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 08:46:01.599971 [ 2085 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032e79999 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032e796c3 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032e7ac23 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b0aef87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae681 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:46:02.421912 [ 2084 ] {a3934168-5e87-469d-8661-fa2c20e7a7ea} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `count` in scope SELECT count. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38064) (comment: 03096_text_log_format_string_args_not_empty.sql) (query 2, line 3) (in query: select count;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000303dd3a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032b465 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:46:02.423308 [ 2142 ] {1ccb77a1-ddca-4eb0-89ff-8007669c32b4} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_6rpenc6i.nonexist' in scope SELECT x FROM test_6rpenc6i.nonexist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38072) (comment: 02932_refreshable_materialized_views_2.sh) (query 1, line 2) (in query: create materialized view o refresh every 1 second (x Int64) engine Memory as select x from nonexist;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae4366 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1098: DB::InterpreterCreateQuery::validateMaterializedViewColumnsAndEngine(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&, std::shared_ptr const&) @ 0x00000000328eecce 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1671: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290048f 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:46:02.425092 [ 2142 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_6rpenc6i.nonexist' in scope SELECT x FROM test_6rpenc6i.nonexist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae4366 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1098: DB::InterpreterCreateQuery::validateMaterializedViewColumnsAndEngine(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&, std::shared_ptr const&) @ 0x00000000328eecce 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1671: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290048f 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:46:02.425141 [ 2084 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `count` in scope SELECT count. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000303dd3a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032b465 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:46:02.438814 [ 2142 ] {78606cb0-062f-450a-af54-323b4b3d8b92} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_6rpenc6i.nonexist' in scope SELECT x FROM test_6rpenc6i.nonexist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38072) (comment: 02932_refreshable_materialized_views_2.sh) (query 2, line 3) (in query: create materialized view o (x Int64) engine Memory as select x from nonexist;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae4366 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1098: DB::InterpreterCreateQuery::validateMaterializedViewColumnsAndEngine(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&, std::shared_ptr const&) @ 0x00000000328eecce 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1671: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290048f 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:46:02.441430 [ 2142 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_6rpenc6i.nonexist' in scope SELECT x FROM test_6rpenc6i.nonexist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae4366 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1098: DB::InterpreterCreateQuery::validateMaterializedViewColumnsAndEngine(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&, std::shared_ptr const&) @ 0x00000000328eecce 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1671: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290048f 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:46:02.654610 [ 2084 ] {5ac3d763-7c00-48e3-a17e-d7d3b0c4417b} executeQuery: Code: 46. DB::Exception: Function with name `conut` does not exist. In scope SELECT conut(). Maybe you meant: ['concat','count']. (UNKNOWN_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38064) (comment: 03096_text_log_format_string_args_not_empty.sql) (query 3, line 5) (in query: select conut();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3350: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003038f5f5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:46:02.656576 [ 2084 ] {} TCPHandler: Code: 46. DB::Exception: Function with name `conut` does not exist. In scope SELECT conut(). Maybe you meant: ['concat','count']. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3350: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003038f5f5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:46:02.677966 [ 2142 ] {9bef5bcb-5545-432c-9ce7-451fad3089da} executeQuery: Code: 81. DB::Exception: Database nope does not exist. (UNKNOWN_DATABASE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38072) (comment: 02932_refreshable_materialized_views_2.sh) (query 3, line 4) (in query: create materialized view o (x Int64) engine Memory as select x from nope.nonexist;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Interpreters/Context.cpp:5680: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000003174f585 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:161: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x0000000031022964 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035d64c 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4364: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c4340 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae4366 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1098: DB::InterpreterCreateQuery::validateMaterializedViewColumnsAndEngine(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&, std::shared_ptr const&) @ 0x00000000328eecce 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1671: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290048f 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:46:02.727647 [ 2142 ] {} TCPHandler: Code: 81. DB::Exception: Database nope does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Interpreters/Context.cpp:5680: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000003174f585 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:161: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x0000000031022964 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035d64c 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4364: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c4340 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae4366 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1098: DB::InterpreterCreateQuery::validateMaterializedViewColumnsAndEngine(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&, std::shared_ptr const&) @ 0x00000000328eecce 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1671: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290048f 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:46:07.564352 [ 3992 ] {5c8937e2-e179-404d-a22c-afef3bbac7ca} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of second argument of function substring, expected (U)Int*: In scope SELECT substring('hello', []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38728) (comment: 01033_function_substring.sql) (query 2, line 3) (in query: SELECT substring('hello', []);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::(anonymous namespace)::FunctionSubstring::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a690453 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:46:07.567418 [ 3992 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of second argument of function substring, expected (U)Int*: In scope SELECT substring('hello', []). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::(anonymous namespace)::FunctionSubstring::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a690453 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:46:07.897015 [ 3992 ] {4d1cf149-31f2-417c-9570-bccb07256031} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of second argument of function substring, expected (U)Int*: In scope SELECT substring('hello', 1, []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38728) (comment: 01033_function_substring.sql) (query 3, line 4) (in query: SELECT substring('hello', 1, []);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::(anonymous namespace)::FunctionSubstring::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a690966 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:46:07.899101 [ 3992 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of second argument of function substring, expected (U)Int*: In scope SELECT substring('hello', 1, []). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::(anonymous namespace)::FunctionSubstring::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a690966 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:46:08.210566 [ 3992 ] {87683793-e4fc-4bc2-ad98-95d60f8111a2} executeQuery: Code: 135. DB::Exception: Indices in strings are 1-based. (ZERO_ARRAY_OR_TUPLE_INDEX) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38728) (comment: 01033_function_substring.sql) (query 5, line 6) (in query: SELECT substring(materialize('hello'), 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::(anonymous namespace)::FunctionSubstring::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a68e525 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301087b6 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000030104ffd 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003ba0ea77 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003bfff312 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032b1845f 15. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x0000000032b01504 16. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:46:08.212938 [ 3992 ] {} TCPHandler: Code: 135. DB::Exception: Indices in strings are 1-based. (ZERO_ARRAY_OR_TUPLE_INDEX), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::(anonymous namespace)::FunctionSubstring::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a68e525 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301087b6 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000030104ffd 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003ba0ea77 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003bfff312 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032b1845f 15. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x0000000032b01504 16. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:46:10.516148 [ 2134 ] {8a9d708b-f51b-4943-b786-60c3e515f272} executeQuery: Code: 36. DB::Exception: Expected Array(Tuple(key, value)) type, got Array(Tuple(UInt64)): In scope SELECT mapApply((k, v) -> tuple(v + 9223372036854775806), col) FROM table_map. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38896) (comment: 02169_map_functions.sql) (query 9, line 10) (in query: SELECT mapApply((k, v) -> tuple(v + 9223372036854775806), col) FROM table_map;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapApply>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b12ce85 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:46:10.521251 [ 2134 ] {} TCPHandler: Code: 36. DB::Exception: Expected Array(Tuple(key, value)) type, got Array(Tuple(UInt64)): In scope SELECT mapApply((k, v) -> tuple(v + 9223372036854775806), col) FROM table_map. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapApply>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b12ce85 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:46:12.052168 [ 410 ] {} CgroupsReader: Cannot find 'kernel' in '/sys/fs/cgroup/memory.stat' (skipped 5940 similar messages) 2025.06.13 08:46:12.925201 [ 4332 ] {82ac02c4-bbf7-4565-add8-bc7a6214e4ee} executeQuery: Code: 248. DB::Exception: Invalid partition format: NO_SUCH_PART. (INVALID_PARTITION_VALUE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39062) (comment: 02004_invalid_partition_mutation_stuck.sql) (query 5, line 15) (in query: ALTER TABLE rep_data MATERIALIZE INDEX idx IN PARTITION ID 'NO_SUCH_PART';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/MergeTreePartInfo.cpp:49: DB::MergeTreePartInfo::validatePartitionID(std::shared_ptr const&, StrongTypedef) @ 0x0000000039d1b161 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6261: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x000000003983064f 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:257: DB::getPartitionAndPredicateExpressionForMutationCommand(DB::MutationCommand const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032dc2cd6 7. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:101: DB::(anonymous namespace)::prepareQueryAffectedAST(std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032dc1223 8. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1439: DB::MutationsInterpreter::validate() @ 0x0000000032e00c90 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:235: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000328957a1 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:46:12.927888 [ 4332 ] {} TCPHandler: Code: 248. DB::Exception: Invalid partition format: NO_SUCH_PART. (INVALID_PARTITION_VALUE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/MergeTreePartInfo.cpp:49: DB::MergeTreePartInfo::validatePartitionID(std::shared_ptr const&, StrongTypedef) @ 0x0000000039d1b161 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6261: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x000000003983064f 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:257: DB::getPartitionAndPredicateExpressionForMutationCommand(DB::MutationCommand const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032dc2cd6 7. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:101: DB::(anonymous namespace)::prepareQueryAffectedAST(std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032dc1223 8. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1439: DB::MutationsInterpreter::validate() @ 0x0000000032e00c90 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:235: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000328957a1 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:46:13.221257 [ 4332 ] {97c1e99f-5656-4c84-9ca2-fd4bc7d1bd22} executeQuery: Code: 248. DB::Exception: Invalid partition format: NO_SUCH_PART. (INVALID_PARTITION_VALUE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39062) (comment: 02004_invalid_partition_mutation_stuck.sql) (query 11, line 31) (in query: ALTER TABLE data MATERIALIZE INDEX idx IN PARTITION ID 'NO_SUCH_PART';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/MergeTreePartInfo.cpp:49: DB::MergeTreePartInfo::validatePartitionID(std::shared_ptr const&, StrongTypedef) @ 0x0000000039d1b161 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6261: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x000000003983064f 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:257: DB::getPartitionAndPredicateExpressionForMutationCommand(DB::MutationCommand const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032dc2cd6 7. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:101: DB::(anonymous namespace)::prepareQueryAffectedAST(std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032dc1223 8. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1439: DB::MutationsInterpreter::validate() @ 0x0000000032e00c90 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:235: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000328957a1 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:46:13.223199 [ 4332 ] {} TCPHandler: Code: 248. DB::Exception: Invalid partition format: NO_SUCH_PART. (INVALID_PARTITION_VALUE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/MergeTreePartInfo.cpp:49: DB::MergeTreePartInfo::validatePartitionID(std::shared_ptr const&, StrongTypedef) @ 0x0000000039d1b161 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6261: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x000000003983064f 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:257: DB::getPartitionAndPredicateExpressionForMutationCommand(DB::MutationCommand const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032dc2cd6 7. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:101: DB::(anonymous namespace)::prepareQueryAffectedAST(std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032dc1223 8. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1439: DB::MutationsInterpreter::validate() @ 0x0000000032e00c90 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:235: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000328957a1 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:46:13.655443 [ 5287 ] {11410bb2-b884-425f-8af2-932d0805b2f9} executeQuery: Code: 6. DB::Exception: Cannot parse string ('') into vector of identifiers. (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38666) (comment: 01515_force_data_skipping_indices.sql) (query 5, line 16) (in query: SELECT * FROM data_01515 SETTINGS force_data_skipping_indices='';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Parsers/parseIdentifierOrStringLiteral.cpp:79: DB::parseIdentifiersOrStringLiterals(String const&, DB::Settings const&) @ 0x000000003e1beb06 5. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:643: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039b370ed 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003c1aa0fb 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003c1a5d42 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003c1a54d7 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003c1bc5b8 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1c2fdc 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049298 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:46:13.658056 [ 5287 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string ('') into vector of identifiers. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Parsers/parseIdentifierOrStringLiteral.cpp:79: DB::parseIdentifiersOrStringLiterals(String const&, DB::Settings const&) @ 0x000000003e1beb06 5. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:643: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039b370ed 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003c1aa0fb 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003c1a5d42 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003c1a54d7 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003c1bc5b8 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1c2fdc 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049298 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:46:13.871699 [ 5287 ] {016009e6-8d76-40b4-88ab-76fc54bf2889} executeQuery: Code: 277. DB::Exception: Index `d1_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38666) (comment: 01515_force_data_skipping_indices.sql) (query 6, line 17) (in query: SELECT * FROM data_01515 SETTINGS force_data_skipping_indices='d1_idx';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:656: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039b3dd73 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003c1aa0fb 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003c1a5d42 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003c1a54d7 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003c1bc5b8 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1c2fdc 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049298 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:46:13.874368 [ 5287 ] {} TCPHandler: Code: 277. DB::Exception: Index `d1_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:656: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039b3dd73 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003c1aa0fb 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003c1a5d42 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003c1a54d7 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003c1bc5b8 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1c2fdc 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049298 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:46:13.893400 [ 5287 ] {16f1e1b9-6347-4cf4-ba17-bfe06f174123} executeQuery: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38666) (comment: 01515_force_data_skipping_indices.sql) (query 7, line 18) (in query: SELECT * FROM data_01515 SETTINGS force_data_skipping_indices='d1_null_idx';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:656: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039b3dd73 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003c1aa0fb 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003c1a5d42 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003c1a54d7 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003c1bc5b8 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1c2fdc 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049298 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:46:13.895891 [ 5287 ] {} TCPHandler: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:656: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039b3dd73 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003c1aa0fb 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003c1a5d42 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003c1a54d7 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003c1bc5b8 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1c2fdc 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049298 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:46:13.935022 [ 2134 ] {df5d902d-7096-42f9-ac9b-ab1b5d276447} executeQuery: Code: 42. DB::Exception: Function mapApply requires at least one argument, passed 0: In scope SELECT mapApply(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38896) (comment: 02169_map_functions.sql) (query 66, line 84) (in query: SELECT mapApply();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000008baf06d 4. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapApply>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b12cba1 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:46:13.937765 [ 2134 ] {} TCPHandler: Code: 42. DB::Exception: Function mapApply requires at least one argument, passed 0: In scope SELECT mapApply(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000008baf06d 4. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapApply>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b12cba1 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:46:14.093766 [ 4015 ] {6cb209e4-d874-4139-a8e9-3956e8906fd0} executeQuery: Code: 107. DB::ErrnoException: Cannot open file /var/lib/clickhouse/format_schemas/nonexist: , errno: 2, strerror: No such file or directory: The table structure cannot be extracted from a Template format file. You can specify the structure manually. (FILE_DOESNT_EXIST) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38690) (comment: 02318_template_schema_inference_bug.sql) (query 2, line 2) (in query: desc file('data_02318.tsv', 'Template') SETTINGS format_template_row='nonexist', format_template_resultset='nonexist';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String&) @ 0x000000001f865f6f 4. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String&) @ 0x000000001f8655e8 5. ./build_docker/./src/IO/ReadBufferFromFile.cpp:48: DB::ReadBufferFromFile::ReadBufferFromFile(String const&, unsigned long, int, char*, unsigned long, std::optional, std::shared_ptr) @ 0x000000001f87bf2a 6. ./build_docker/./src/Formats/ParsedTemplateFormatString.cpp:19: DB::ParsedTemplateFormatString::ParsedTemplateFormatString(DB::FormatSchemaInfo const&, std::function (String const&)> const&, bool) @ 0x000000003b8faf9f 7. ./build_docker/./src/Processors/Formats/Impl/TemplateRowInputFormat.cpp:562: DB::fillRowFormat(DB::FormatSettings const&, std::function (String const&)>, bool) @ 0x000000003b90c67a 8. ./build_docker/./src/Processors/Formats/Impl/TemplateRowInputFormat.cpp:614: String std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*, DB::FormatSettings const&) @ 0x000000003b90d430 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ae9a723 10. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:578: DB::getKeysForSchemaCache(std::vector> const&, String const&, std::optional const&, std::shared_ptr const&) @ 0x000000003afda6de 11. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:562: DB::getKeyForSchemaCache(String const&, String const&, std::optional const&, std::shared_ptr const&) @ 0x000000003afd9fff 12. ./build_docker/./src/Storages/StorageFile.cpp:590: DB::(anonymous namespace)::ReadBufferFromFileIterator::tryGetColumnsFromCache(std::vector> const&) @ 0x000000003843d7f0 13. ./build_docker/./src/Storages/StorageFile.cpp:473: DB::(anonymous namespace)::ReadBufferFromFileIterator::next() @ 0x0000000038438341 14. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:152: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003afcb1ca 15. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003afd97ae 16. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000383fa9db 17. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000383fbede 18. ./build_docker/./src/TableFunctions/TableFunctionFile.cpp:119: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002660b1f3 19. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x00000000338721cc 20. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x000000003386e605 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 08:46:14.097617 [ 4015 ] {} TCPHandler: Code: 107. DB::ErrnoException: Cannot open file /var/lib/clickhouse/format_schemas/nonexist: , errno: 2, strerror: No such file or directory: The table structure cannot be extracted from a Template format file. You can specify the structure manually. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String&) @ 0x000000001f865f6f 4. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String&) @ 0x000000001f8655e8 5. ./build_docker/./src/IO/ReadBufferFromFile.cpp:48: DB::ReadBufferFromFile::ReadBufferFromFile(String const&, unsigned long, int, char*, unsigned long, std::optional, std::shared_ptr) @ 0x000000001f87bf2a 6. ./build_docker/./src/Formats/ParsedTemplateFormatString.cpp:19: DB::ParsedTemplateFormatString::ParsedTemplateFormatString(DB::FormatSchemaInfo const&, std::function (String const&)> const&, bool) @ 0x000000003b8faf9f 7. ./build_docker/./src/Processors/Formats/Impl/TemplateRowInputFormat.cpp:562: DB::fillRowFormat(DB::FormatSettings const&, std::function (String const&)>, bool) @ 0x000000003b90c67a 8. ./build_docker/./src/Processors/Formats/Impl/TemplateRowInputFormat.cpp:614: String std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*, DB::FormatSettings const&) @ 0x000000003b90d430 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ae9a723 10. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:578: DB::getKeysForSchemaCache(std::vector> const&, String const&, std::optional const&, std::shared_ptr const&) @ 0x000000003afda6de 11. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:562: DB::getKeyForSchemaCache(String const&, String const&, std::optional const&, std::shared_ptr const&) @ 0x000000003afd9fff 12. ./build_docker/./src/Storages/StorageFile.cpp:590: DB::(anonymous namespace)::ReadBufferFromFileIterator::tryGetColumnsFromCache(std::vector> const&) @ 0x000000003843d7f0 13. ./build_docker/./src/Storages/StorageFile.cpp:473: DB::(anonymous namespace)::ReadBufferFromFileIterator::next() @ 0x0000000038438341 14. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:152: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003afcb1ca 15. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003afd97ae 16. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000383fa9db 17. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000383fbede 18. ./build_docker/./src/TableFunctions/TableFunctionFile.cpp:119: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002660b1f3 19. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x00000000338721cc 20. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x000000003386e605 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 08:46:14.115237 [ 5287 ] {a4d723a2-bc59-4c1c-b924-aaa193c5ba9c} executeQuery: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38666) (comment: 01515_force_data_skipping_indices.sql) (query 12, line 24) (in query: SELECT * FROM data_01515 WHERE d1 = 0 SETTINGS force_data_skipping_indices='d1_idx,d1_null_idx';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:656: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039b3dd73 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003c1aa0fb 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003c1a5d42 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003c1a54d7 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003c1bc5b8 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1c2fdc 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049298 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:46:14.117805 [ 5287 ] {} TCPHandler: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:656: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039b3dd73 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003c1aa0fb 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003c1a5d42 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003c1a54d7 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003c1bc5b8 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1c2fdc 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049298 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:46:14.144983 [ 5287 ] {d4b3f27c-89d0-4d89-8b03-c2a0ec789a60} executeQuery: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38666) (comment: 01515_force_data_skipping_indices.sql) (query 13, line 25) (in query: SELECT * FROM data_01515 WHERE d1 = 0 SETTINGS force_data_skipping_indices='d1_null_idx,d1_idx';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:656: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039b3dd73 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003c1aa0fb 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003c1a5d42 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003c1a54d7 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003c1bc5b8 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1c2fdc 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049298 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:46:14.147210 [ 5287 ] {} TCPHandler: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:656: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039b3dd73 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003c1aa0fb 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003c1a5d42 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003c1a54d7 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003c1bc5b8 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1c2fdc 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049298 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:46:14.174311 [ 5287 ] {948016f3-611b-41ad-b13a-d721f34080a3} executeQuery: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38666) (comment: 01515_force_data_skipping_indices.sql) (query 14, line 26) (in query: SELECT * FROM data_01515 WHERE d1 = 0 SETTINGS force_data_skipping_indices='d1_null_idx,d1_idx,,';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:656: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039b3dd73 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003c1aa0fb 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003c1a5d42 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003c1a54d7 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003c1bc5b8 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1c2fdc 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049298 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:46:14.176423 [ 5287 ] {} TCPHandler: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:656: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039b3dd73 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003c1aa0fb 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003c1a5d42 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003c1a54d7 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003c1bc5b8 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1c2fdc 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049298 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:46:14.205146 [ 5287 ] {f7f5945b-34ba-4797-a0d9-7b22262eda42} executeQuery: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38666) (comment: 01515_force_data_skipping_indices.sql) (query 15, line 27) (in query: SELECT * FROM data_01515 WHERE d1 = 0 SETTINGS force_data_skipping_indices=' d1_null_idx,d1_idx';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:656: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039b3dd73 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003c1aa0fb 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003c1a5d42 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003c1a54d7 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003c1bc5b8 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1c2fdc 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049298 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:46:14.207887 [ 5287 ] {} TCPHandler: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:656: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039b3dd73 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003c1aa0fb 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003c1a5d42 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003c1a54d7 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003c1bc5b8 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1c2fdc 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049298 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:46:14.230041 [ 2134 ] {866380fa-5655-4f52-a5fa-9cc1fb903de3} executeQuery: Code: 36. DB::Exception: Expected Array(Tuple(key, value)) type, got Array(UInt8): In scope SELECT mapApply((x, y) -> x, map(1, 0, 2, 0)). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38896) (comment: 02169_map_functions.sql) (query 67, line 85) (in query: SELECT mapApply((x, y) -> (x), map(1, 0, 2, 0));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapApply>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b12c90a 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:46:14.232967 [ 2134 ] {} TCPHandler: Code: 36. DB::Exception: Expected Array(Tuple(key, value)) type, got Array(UInt8): In scope SELECT mapApply((x, y) -> x, map(1, 0, 2, 0)). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapApply>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b12c90a 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:46:14.236366 [ 5287 ] {e0e990ae-d6b3-4bf1-af7a-c4c4e5a85577} executeQuery: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38666) (comment: 01515_force_data_skipping_indices.sql) (query 16, line 28) (in query: SELECT * FROM data_01515 WHERE d1 = 0 SETTINGS force_data_skipping_indices=' `d1_null_idx`,d1_idx';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:656: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039b3dd73 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003c1aa0fb 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003c1a5d42 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003c1a54d7 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003c1bc5b8 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1c2fdc 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049298 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:46:14.238397 [ 5287 ] {} TCPHandler: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:656: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039b3dd73 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003c1aa0fb 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003c1a5d42 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003c1a54d7 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003c1bc5b8 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1c2fdc 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049298 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:46:14.251297 [ 2134 ] {59b7529c-fd76-42c0-8190-686450d4c26e} executeQuery: Code: 36. DB::Exception: Expected Array(Tuple(key, value)) type, got Array(String): In scope SELECT mapApply((x, y) -> 'x', map(1, 0, 2, 0)). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38896) (comment: 02169_map_functions.sql) (query 68, line 86) (in query: SELECT mapApply((x, y) -> ('x'), map(1, 0, 2, 0));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapApply>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b12c90a 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:46:14.253917 [ 2134 ] {} TCPHandler: Code: 36. DB::Exception: Expected Array(Tuple(key, value)) type, got Array(String): In scope SELECT mapApply((x, y) -> 'x', map(1, 0, 2, 0)). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapApply>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b12c90a 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:46:14.266643 [ 5287 ] {b2ffc7f7-e6dc-4d1f-874e-d9ba4a16a852} executeQuery: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38666) (comment: 01515_force_data_skipping_indices.sql) (query 17, line 29) (in query: SELECT * FROM data_01515 WHERE d1 = 0 SETTINGS force_data_skipping_indices='d1_null_idx';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:656: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039b3dd73 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003c1aa0fb 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003c1a5d42 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003c1a54d7 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003c1bc5b8 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1c2fdc 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049298 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:46:14.268712 [ 5287 ] {} TCPHandler: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:656: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039b3dd73 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003c1aa0fb 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003c1a5d42 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003c1a54d7 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003c1bc5b8 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1c2fdc 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049298 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:46:14.307791 [ 5287 ] {87500062-1d37-4673-9f7b-f6ca41daa10e} executeQuery: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38666) (comment: 01515_force_data_skipping_indices.sql) (query 18, line 30) (in query: SELECT * FROM data_01515 WHERE d1 = 0 SETTINGS force_data_skipping_indices=' d1_null_idx ';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:656: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039b3dd73 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003c1aa0fb 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003c1a5d42 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003c1a54d7 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003c1bc5b8 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1c2fdc 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049298 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:46:14.311077 [ 5287 ] {} TCPHandler: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:656: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039b3dd73 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003c1aa0fb 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003c1a5d42 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003c1a54d7 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003c1bc5b8 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1c2fdc 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049298 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:46:14.320312 [ 2134 ] {e195c7d3-07b7-4a49-843f-f1cad636e427} executeQuery: Code: 36. DB::Exception: Expected Array(Tuple(key, value)) type, got Array(Tuple(UInt8, UInt8, UInt8)): In scope SELECT mapApply((x, y) -> (x, 1, 2), map(1, 0, 2, 0)). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38896) (comment: 02169_map_functions.sql) (query 70, line 88) (in query: SELECT mapApply((x, y) -> (x, 1, 2), map(1, 0, 2, 0));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapApply>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b12ce85 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:46:14.322900 [ 2134 ] {} TCPHandler: Code: 36. DB::Exception: Expected Array(Tuple(key, value)) type, got Array(Tuple(UInt8, UInt8, UInt8)): In scope SELECT mapApply((x, y) -> (x, 1, 2), map(1, 0, 2, 0)). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapApply>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b12ce85 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:46:14.344732 [ 5287 ] {c2726730-a30a-4c52-a687-2d15e8cf5834} executeQuery: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38666) (comment: 01515_force_data_skipping_indices.sql) (query 19, line 32) (in query: SELECT * FROM data_01515 WHERE d1_null = 0 SETTINGS force_data_skipping_indices='d1_null_idx';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:656: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039b3dd73 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003c1aa0fb 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003c1a5d42 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003c1a54d7 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003c1bc5b8 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1c2fdc 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049298 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:46:14.347678 [ 5287 ] {} TCPHandler: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:656: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039b3dd73 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003c1aa0fb 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003c1a5d42 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003c1a54d7 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003c1bc5b8 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1c2fdc 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049298 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:46:14.585077 [ 2134 ] {2b9924fd-4f0e-484e-95b8-df1eaaff0e4a} executeQuery: Code: 43. DB::Exception: Function mapApply requires at least one argument of type Map. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38896) (comment: 02169_map_functions.sql) (query 71, line 89) (in query: SELECT mapApply((x, y) -> (x, x + 1));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c2574a 4. DB::MapAdapterBase, DB::NameMapApply>::extractNestedTypes(std::vector, std::allocator>>&) @ 0x000000001b139657 5. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapApply>::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x000000001b12d775 6. DB::FunctionToOverloadResolverAdaptor::getLambdaArgumentTypesImpl(std::vector, std::allocator>>&) const @ 0x000000000de951d1 7. DB::IFunctionOverloadResolver::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x000000002bffa5db 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3389: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037e25d 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 08:46:14.587820 [ 2134 ] {} TCPHandler: Code: 43. DB::Exception: Function mapApply requires at least one argument of type Map. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c2574a 4. DB::MapAdapterBase, DB::NameMapApply>::extractNestedTypes(std::vector, std::allocator>>&) @ 0x000000001b139657 5. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapApply>::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x000000001b12d775 6. DB::FunctionToOverloadResolverAdaptor::getLambdaArgumentTypesImpl(std::vector, std::allocator>>&) const @ 0x000000000de951d1 7. DB::IFunctionOverloadResolver::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x000000002bffa5db 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3389: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037e25d 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 08:46:14.858565 [ 2134 ] {00ecc3ab-2ab4-4b05-a824-bc997f45e3a8} executeQuery: Code: 43. DB::Exception: Argument 2 of function arrayMap must be Array. Found Function((?, ?) -> ?) instead. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38896) (comment: 02169_map_functions.sql) (query 72, line 90) (in query: SELECT mapApply(map(1, 0, 2, 0), (x, y) -> (x, x + 1));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&) @ 0x00000000173a3e77 4. DB::FunctionArrayMapped::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x000000001b1363f5 5. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapApply>::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x000000001b12d784 6. DB::FunctionToOverloadResolverAdaptor::getLambdaArgumentTypesImpl(std::vector, std::allocator>>&) const @ 0x000000000de951d1 7. DB::IFunctionOverloadResolver::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x000000002bffa5db 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3389: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037e25d 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 08:46:14.861344 [ 2134 ] {} TCPHandler: Code: 43. DB::Exception: Argument 2 of function arrayMap must be Array. Found Function((?, ?) -> ?) instead. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&) @ 0x00000000173a3e77 4. DB::FunctionArrayMapped::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x000000001b1363f5 5. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapApply>::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x000000001b12d784 6. DB::FunctionToOverloadResolverAdaptor::getLambdaArgumentTypesImpl(std::vector, std::allocator>>&) const @ 0x000000000de951d1 7. DB::IFunctionOverloadResolver::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x000000002bffa5db 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3389: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037e25d 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 08:46:15.190077 [ 2134 ] {bfd2a625-7629-4631-9aef-497dbbcedf67} executeQuery: Code: 43. DB::Exception: Illegal types Tuple(keys UInt8, values UInt8) and UInt8 of arguments of function plus: In scope (x, y) -> (x, x + 1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38896) (comment: 02169_map_functions.sql) (query 73, line 91) (in query: SELECT mapApply((x, y) -> (x, x+1), map(1, 0, 2, 0), map(1, 0, 2, 0));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000018add5c3 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000183cb719 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a174126 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2670: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x00000000303add95 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3434: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037fa3b 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:46:15.193445 [ 2134 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Tuple(keys UInt8, values UInt8) and UInt8 of arguments of function plus: In scope (x, y) -> (x, x + 1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000018add5c3 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000183cb719 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a174126 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2670: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x00000000303add95 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3434: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037fa3b 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:46:15.457642 [ 2134 ] {7f94d29e-6bc4-4711-a1db-baf338ab575a} executeQuery: Code: 42. DB::Exception: Function mapFilter requires at least one argument, passed 0: In scope SELECT mapFilter(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38896) (comment: 02169_map_functions.sql) (query 74, line 93) (in query: SELECT mapFilter();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000008baf06d 4. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapFilter>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b110dad 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:46:15.459890 [ 2134 ] {} TCPHandler: Code: 42. DB::Exception: Function mapFilter requires at least one argument, passed 0: In scope SELECT mapFilter(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000008baf06d 4. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapFilter>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b110dad 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:46:15.474269 [ 5281 ] {7baabb8c-f903-49a3-8b11-aa4e591ba571} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 6.00, current rows: 10.00. (TOO_MANY_ROWS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38710) (comment: 01114_materialize_clear_index_compact_parts.sql) (query 15, line 31) (in query: SELECT count() FROM minmax_compact WHERE i64 = 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f24bc97 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f24776e 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f247bac 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000003c166bc3 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1c31d7 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049298 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:46:15.477509 [ 5281 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 6.00, current rows: 10.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f24bc97 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f24776e 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f247bac 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000003c166bc3 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1c31d7 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049298 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:46:15.754217 [ 2134 ] {5894598b-159d-48cb-b9e9-6de42345c861} executeQuery: Code: 43. DB::Exception: Expression for function arrayFilter must return UInt8 or Nullable(UInt8), found Int32: In scope SELECT mapFilter((x, y) -> toInt32(x), map(1, 0, 2, 0)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38896) (comment: 02169_map_functions.sql) (query 75, line 94) (in query: SELECT mapFilter((x, y) -> (toInt32(x)), map(1, 0, 2, 0));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::FunctionArrayMapped::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b11a7e1 5. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapFilter>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b1105fd 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:46:15.756657 [ 2134 ] {} TCPHandler: Code: 43. DB::Exception: Expression for function arrayFilter must return UInt8 or Nullable(UInt8), found Int32: In scope SELECT mapFilter((x, y) -> toInt32(x), map(1, 0, 2, 0)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::FunctionArrayMapped::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b11a7e1 5. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapFilter>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b1105fd 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:46:15.780116 [ 2134 ] {2c3dfa33-f3ce-43b9-9c8d-e3cdd41d3ab6} executeQuery: Code: 43. DB::Exception: Expression for function arrayFilter must return UInt8 or Nullable(UInt8), found String: In scope SELECT mapFilter((x, y) -> 'x', map(1, 0, 2, 0)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38896) (comment: 02169_map_functions.sql) (query 76, line 95) (in query: SELECT mapFilter((x, y) -> ('x'), map(1, 0, 2, 0));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::FunctionArrayMapped::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b11a7e1 5. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapFilter>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b1105fd 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:46:15.783377 [ 2134 ] {} TCPHandler: Code: 43. DB::Exception: Expression for function arrayFilter must return UInt8 or Nullable(UInt8), found String: In scope SELECT mapFilter((x, y) -> 'x', map(1, 0, 2, 0)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::FunctionArrayMapped::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b11a7e1 5. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapFilter>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b1105fd 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:46:15.803881 [ 2134 ] {2b4ab862-8665-4f63-a689-2c2341692324} executeQuery: Code: 43. DB::Exception: Expression for function arrayFilter must return UInt8 or Nullable(UInt8), found Tuple(Tuple(keys UInt8, values UInt8), Tuple(keys UInt8, values UInt8)): In scope SELECT mapFilter(x -> (x, x), map(1, 0, 2, 0)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38896) (comment: 02169_map_functions.sql) (query 77, line 96) (in query: SELECT mapFilter((x) -> (x, x), map(1, 0, 2, 0));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::FunctionArrayMapped::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b11a7e1 5. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapFilter>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b1105fd 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:46:15.807059 [ 2134 ] {} TCPHandler: Code: 43. DB::Exception: Expression for function arrayFilter must return UInt8 or Nullable(UInt8), found Tuple(Tuple(keys UInt8, values UInt8), Tuple(keys UInt8, values UInt8)): In scope SELECT mapFilter(x -> (x, x), map(1, 0, 2, 0)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::FunctionArrayMapped::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b11a7e1 5. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapFilter>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b1105fd 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:46:15.830420 [ 2134 ] {9079e612-0e28-4710-a53d-3a31a418fa1e} executeQuery: Code: 43. DB::Exception: Expression for function arrayFilter must return UInt8 or Nullable(UInt8), found Tuple(UInt8, UInt8, UInt8): In scope SELECT mapFilter((x, y) -> (x, 1, 2), map(1, 0, 2, 0)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38896) (comment: 02169_map_functions.sql) (query 78, line 97) (in query: SELECT mapFilter((x, y) -> (x, 1, 2), map(1, 0, 2, 0));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::FunctionArrayMapped::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b11a7e1 5. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapFilter>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b1105fd 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:46:15.833102 [ 2134 ] {} TCPHandler: Code: 43. DB::Exception: Expression for function arrayFilter must return UInt8 or Nullable(UInt8), found Tuple(UInt8, UInt8, UInt8): In scope SELECT mapFilter((x, y) -> (x, 1, 2), map(1, 0, 2, 0)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::FunctionArrayMapped::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b11a7e1 5. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapFilter>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b1105fd 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:46:16.086235 [ 2134 ] {a23b0eaa-2001-4493-9c42-b9c91aa9c932} executeQuery: Code: 43. DB::Exception: Function mapFilter requires at least one argument of type Map. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38896) (comment: 02169_map_functions.sql) (query 79, line 98) (in query: SELECT mapFilter((x, y) -> (x, x + 1));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c2574a 4. DB::MapAdapterBase, DB::NameMapFilter>::extractNestedTypes(std::vector, std::allocator>>&) @ 0x000000001b1296d7 5. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapFilter>::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x000000001b111075 6. DB::FunctionToOverloadResolverAdaptor::getLambdaArgumentTypesImpl(std::vector, std::allocator>>&) const @ 0x000000000de951d1 7. DB::IFunctionOverloadResolver::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x000000002bffa5db 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3389: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037e25d 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 08:46:16.088456 [ 2134 ] {} TCPHandler: Code: 43. DB::Exception: Function mapFilter requires at least one argument of type Map. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c2574a 4. DB::MapAdapterBase, DB::NameMapFilter>::extractNestedTypes(std::vector, std::allocator>>&) @ 0x000000001b1296d7 5. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapFilter>::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x000000001b111075 6. DB::FunctionToOverloadResolverAdaptor::getLambdaArgumentTypesImpl(std::vector, std::allocator>>&) const @ 0x000000000de951d1 7. DB::IFunctionOverloadResolver::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x000000002bffa5db 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3389: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037e25d 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 08:46:16.339716 [ 2134 ] {1043b64a-9fd1-4eae-879b-83a6e00745e5} executeQuery: Code: 43. DB::Exception: Argument 2 of function arrayFilter must be Array. Found Function((?, ?) -> ?) instead. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38896) (comment: 02169_map_functions.sql) (query 80, line 99) (in query: SELECT mapFilter(map(1, 0, 2, 0), (x, y) -> (x > 0));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&) @ 0x00000000173a3e77 4. DB::FunctionArrayMapped::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x000000001b11ca75 5. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapFilter>::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x000000001b111084 6. DB::FunctionToOverloadResolverAdaptor::getLambdaArgumentTypesImpl(std::vector, std::allocator>>&) const @ 0x000000000de951d1 7. DB::IFunctionOverloadResolver::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x000000002bffa5db 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3389: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037e25d 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 08:46:16.342116 [ 2134 ] {} TCPHandler: Code: 43. DB::Exception: Argument 2 of function arrayFilter must be Array. Found Function((?, ?) -> ?) instead. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&) @ 0x00000000173a3e77 4. DB::FunctionArrayMapped::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x000000001b11ca75 5. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapFilter>::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x000000001b111084 6. DB::FunctionToOverloadResolverAdaptor::getLambdaArgumentTypesImpl(std::vector, std::allocator>>&) const @ 0x000000000de951d1 7. DB::IFunctionOverloadResolver::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x000000002bffa5db 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3389: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037e25d 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 08:46:16.363524 [ 2134 ] {a670d021-1b87-4a62-a075-65f96c79c008} executeQuery: Code: 43. DB::Exception: Illegal types Tuple(keys UInt8, values UInt8) and UInt8 of arguments of function plus: In scope (x, y) -> (x, x + 1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38896) (comment: 02169_map_functions.sql) (query 81, line 100) (in query: SELECT mapFilter((x, y) -> (x, x + 1), map(1, 0, 2, 0), map(1, 0, 2, 0));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000018add5c3 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000183cb719 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a174126 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2670: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x00000000303add95 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3434: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037fa3b 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:46:16.365740 [ 2134 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Tuple(keys UInt8, values UInt8) and UInt8 of arguments of function plus: In scope (x, y) -> (x, x + 1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000018add5c3 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000183cb719 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a174126 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2670: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x00000000303add95 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3434: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037fa3b 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:46:16.625691 [ 2134 ] {ba2ca038-3a24-47a2-bb3d-4f2ded13d968} executeQuery: Code: 386. DB::Exception: There is no supertype for types UInt8, Tuple(keys UInt8, values UInt8) because some of them are Tuple and some of them are not: In scope SELECT mapConcat([1, 2], map(1, 2)). (NO_COMMON_TYPE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38896) (comment: 02169_map_functions.sql) (query 82, line 102) (in query: SELECT mapConcat([1, 2], map(1, 2));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f4977a2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:401: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f4a5f80 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:357: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f4a0e8a 6. DB::FunctionArrayConcat::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b2b9d63 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 8. DB::FunctionMapToArrayAdapter, DB::NameMapConcat>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001aff2ba9 9. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 10. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 2025.06.13 08:46:16.628509 [ 2134 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types UInt8, Tuple(keys UInt8, values UInt8) because some of them are Tuple and some of them are not: In scope SELECT mapConcat([1, 2], map(1, 2)). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f4977a2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:401: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f4a5f80 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:357: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f4a0e8a 6. DB::FunctionArrayConcat::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b2b9d63 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 8. DB::FunctionMapToArrayAdapter, DB::NameMapConcat>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001aff2ba9 9. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 10. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 2025.06.13 08:46:16.921113 [ 2134 ] {80c223fc-a421-4ee3-9c36-5f7cf78143e1} executeQuery: Code: 43. DB::Exception: First argument for function arraySort must be a function. Actual Array(Tuple(keys UInt8, values UInt8)): In scope SELECT mapSort(map(1, 2), map(3, 4)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38896) (comment: 02169_map_functions.sql) (query 83, line 103) (in query: SELECT mapSort(map(1, 2), map(3, 4));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::FunctionArrayMapped, DB::NameArraySort>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b164b2d 5. DB::FunctionMapToArrayAdapter, DB::NameArraySort>, DB::MapToNestedAdapter, DB::NameMapSort>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b15d3dd 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:46:16.923741 [ 2134 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arraySort must be a function. Actual Array(Tuple(keys UInt8, values UInt8)): In scope SELECT mapSort(map(1, 2), map(3, 4)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::FunctionArrayMapped, DB::NameArraySort>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b164b2d 5. DB::FunctionMapToArrayAdapter, DB::NameArraySort>, DB::MapToNestedAdapter, DB::NameMapSort>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b15d3dd 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:46:17.192962 [ 2134 ] {ab692843-8296-48db-bb64-d87b84001774} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapUpdate doesn't match: passed 0, should be 2: In scope SELECT mapUpdate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38896) (comment: 02169_map_functions.sql) (query 84, line 105) (in query: SELECT mapUpdate();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:46:17.195905 [ 2134 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapUpdate doesn't match: passed 0, should be 2: In scope SELECT mapUpdate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:46:17.214474 [ 2134 ] {12e26ff4-018e-4ac4-b7bc-b087633b6685} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapUpdate doesn't match: passed 3, should be 2: In scope SELECT mapUpdate(map(1, 3, 3, 2), map(1, 0, 2, 0), map(1, 0, 2, 0)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38896) (comment: 02169_map_functions.sql) (query 85, line 106) (in query: SELECT mapUpdate(map(1, 3, 3, 2), map(1, 0, 2, 0), map(1, 0, 2, 0));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:46:17.217061 [ 2134 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapUpdate doesn't match: passed 3, should be 2: In scope SELECT mapUpdate(map(1, 3, 3, 2), map(1, 0, 2, 0), map(1, 0, 2, 0)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:46:17.791479 [ 5287 ] {0062ecb0-6f39-43dc-ad3b-7cc99907ac89} executeQuery: Poco::Exception. Code: 1000, e.code() = 0, Exception: Unsupported language for region name. Supported languages are: 'ru', 'en', 'ua', 'uk', 'by', 'kz', 'tr', 'de', 'uz', 'lv', 'lt', 'et', 'pt', 'he', 'vi', 'es'. (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38880) (comment: 02411_legacy_geobase.sql) (query 2, line 4) (in query: SELECT regionToName(number::UInt32, 'xy') FROM numbers(13);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String&&, int) @ 0x00000000411eaf26 1. DB::RegionsNames::getLanguageEnum(String const&) @ 0x000000000907d81d 2. DB::FunctionRegionToName::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000907a53b 3. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 4. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 8. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301087b6 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000030104ffd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003ba0ea77 11. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003bfff312 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032b1845f 13. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x0000000032b01504 14. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:46:17.793955 [ 5287 ] {} TCPHandler: Code: 1000. DB::Exception: Exception: Unsupported language for region name. Supported languages are: 'ru', 'en', 'ua', 'uk', 'by', 'kz', 'tr', 'de', 'uz', 'lv', 'lt', 'et', 'pt', 'he', 'vi', 'es'. (POCO_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String&&, int) @ 0x00000000411eaf26 1. DB::RegionsNames::getLanguageEnum(String const&) @ 0x000000000907d81d 2. DB::FunctionRegionToName::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000907a53b 3. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 4. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 8. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301087b6 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000030104ffd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003ba0ea77 11. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003bfff312 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032b1845f 13. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x0000000032b01504 14. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:46:19.744390 [ 4015 ] {d7ba8cdb-b071-40f4-a680-6075cfaa055f} executeQuery: Code: 43. DB::Exception: First argument for this overload of arrayMap must be a function with 1 arguments, found Function((?, ?, ?) -> ?) instead. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38970) (comment: 02706_array_map_tuples.sql) (query 4, line 5) (in query: WITH [(1, 2)] AS arr1 SELECT arrayMap((x, y, z) -> (y, x, z), arr1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000008bd1817 4. DB::FunctionArrayMapped::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x000000001b136f49 5. DB::FunctionToOverloadResolverAdaptor::getLambdaArgumentTypesImpl(std::vector, std::allocator>>&) const @ 0x000000000de951d1 6. DB::IFunctionOverloadResolver::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x000000002bffa5db 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3389: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037e25d 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 29. ? @ 0x00007f5206343ac3 30. ? @ 0x00007f52063d5850 2025.06.13 08:46:19.746876 [ 4015 ] {} TCPHandler: Code: 43. DB::Exception: First argument for this overload of arrayMap must be a function with 1 arguments, found Function((?, ?, ?) -> ?) instead. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000008bd1817 4. DB::FunctionArrayMapped::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x000000001b136f49 5. DB::FunctionToOverloadResolverAdaptor::getLambdaArgumentTypesImpl(std::vector, std::allocator>>&) const @ 0x000000000de951d1 6. DB::IFunctionOverloadResolver::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x000000002bffa5db 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3389: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037e25d 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 29. ? @ 0x00007f5206343ac3 30. ? @ 0x00007f52063d5850 2025.06.13 08:46:19.764704 [ 4015 ] {efb45556-ea95-4fe2-b155-cebd076ec122} executeQuery: Code: 43. DB::Exception: First argument for this overload of arrayMap must be a function with 1 arguments, found Function((?, ?) -> ?) instead. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38970) (comment: 02706_array_map_tuples.sql) (query 5, line 6) (in query: WITH [1, 2] AS arr1 SELECT arrayMap((x, y) -> (y, x), arr1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000008bd1817 4. DB::FunctionArrayMapped::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x000000001b136f49 5. DB::FunctionToOverloadResolverAdaptor::getLambdaArgumentTypesImpl(std::vector, std::allocator>>&) const @ 0x000000000de951d1 6. DB::IFunctionOverloadResolver::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x000000002bffa5db 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3389: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037e25d 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 29. ? @ 0x00007f5206343ac3 30. ? @ 0x00007f52063d5850 2025.06.13 08:46:19.767284 [ 4015 ] {} TCPHandler: Code: 43. DB::Exception: First argument for this overload of arrayMap must be a function with 1 arguments, found Function((?, ?) -> ?) instead. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000008bd1817 4. DB::FunctionArrayMapped::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x000000001b136f49 5. DB::FunctionToOverloadResolverAdaptor::getLambdaArgumentTypesImpl(std::vector, std::allocator>>&) const @ 0x000000000de951d1 6. DB::IFunctionOverloadResolver::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x000000002bffa5db 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3389: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037e25d 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 29. ? @ 0x00007f5206343ac3 30. ? @ 0x00007f52063d5850 2025.06.13 08:46:25.150213 [ 2142 ] {da9f0a40-2cd9-408a-aee9-e611c2897818} executeQuery: Code: 469. DB::Exception: Constraint `c` for table test_bqzjpy4g.default_constraints (0c480b18-2b29-44ab-8764-db5486cec028) is violated at row 5. Expression: (y < 5). Column values: y = 5. (VIOLATED_CONSTRAINT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37940) (comment: 01286_constraints_on_default.sql) (query 3, line 9) (in query: INSERT INTO default_constraints (x) SELECT number FROM system.numbers LIMIT 5;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f626f47 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003b9da9fe 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:46:25.224946 [ 2142 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `c` for table test_bqzjpy4g.default_constraints (0c480b18-2b29-44ab-8764-db5486cec028) is violated at row 5. Expression: (y < 5). Column values: y = 5. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f626f47 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003b9da9fe 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 08:46:25.426225 [ 2142 ] {a37dc9b6-ac54-49e4-99f8-359ca8e78795} executeQuery: Code: 469. DB::Exception: Constraint `c` for table test_bqzjpy4g.default_constraints (0c480b18-2b29-44ab-8764-db5486cec028) is violated at row 5. Expression: (y < 5). Column values: y = 5. (VIOLATED_CONSTRAINT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37940) (comment: 01286_constraints_on_default.sql) (query 4, line 10) (in query: INSERT INTO default_constraints (x) VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f626f47 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003b9da9fe 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b10197a 12. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003adbc219 13. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x000000003ad8e9f8 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:46:25.430106 [ 2142 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `c` for table test_bqzjpy4g.default_constraints (0c480b18-2b29-44ab-8764-db5486cec028) is violated at row 5. Expression: (y < 5). Column values: y = 5. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f626f47 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003b9da9fe 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b10197a 12. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003adbc219 13. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x000000003ad8e9f8 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:46:25.612921 [ 2142 ] {e1e32f5d-1d76-4097-bc36-8abe95f8ba06} executeQuery: Code: 469. DB::Exception: Constraint `c` for table _temporary_and_external_tables.`_tmp_0008e825-7ef6-482c-a20a-84c44deddff2` (0008e825-7ef6-482c-a20a-84c44deddff2) is violated at row 5. Expression: (y < 5). Column values: y = 5. (VIOLATED_CONSTRAINT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37940) (comment: 01286_constraints_on_default.sql) (query 9, line 25) (in query: INSERT INTO default_constraints (x) SELECT number FROM system.numbers LIMIT 5;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f626f47 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003b9da9fe 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:46:25.616523 [ 2142 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `c` for table _temporary_and_external_tables.`_tmp_0008e825-7ef6-482c-a20a-84c44deddff2` (0008e825-7ef6-482c-a20a-84c44deddff2) is violated at row 5. Expression: (y < 5). Column values: y = 5. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f626f47 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003b9da9fe 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 08:46:25.643925 [ 2142 ] {2b7c7f2a-7b17-405d-aa51-99b8bb49a0af} executeQuery: Code: 469. DB::Exception: Constraint `c` for table _temporary_and_external_tables.`_tmp_0008e825-7ef6-482c-a20a-84c44deddff2` (0008e825-7ef6-482c-a20a-84c44deddff2) is violated at row 5. Expression: (y < 5). Column values: y = 5. (VIOLATED_CONSTRAINT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37940) (comment: 01286_constraints_on_default.sql) (query 10, line 26) (in query: INSERT INTO default_constraints (x) VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f626f47 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003b9da9fe 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b10197a 12. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003adbc219 13. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x000000003ad8e9f8 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:46:25.647707 [ 2142 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `c` for table _temporary_and_external_tables.`_tmp_0008e825-7ef6-482c-a20a-84c44deddff2` (0008e825-7ef6-482c-a20a-84c44deddff2) is violated at row 5. Expression: (y < 5). Column values: y = 5. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f626f47 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003b9da9fe 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b10197a 12. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003adbc219 13. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x000000003ad8e9f8 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:46:40.213155 [ 5287 ] {6dc728cc-e667-42e5-bb0e-ea45098377ea} executeQuery: Code: 43. DB::Exception: The INTERVAL must be a week or shorter, 'IntervalMonth' given. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43540) (comment: 02346_non_negative_derivative.sql) (query 16, line 50) (in query: -- shall not work for month, quarter, year (intervals with floating number of seconds) -- Month SELECT ts, metric, nonNegativeDerivative(metric, ts, INTERVAL 11 MONTH) OVER (PARTITION BY metric ORDER BY ts, metric ASC Rows BETWEEN UNBOUNDED PRECEDING AND UNBOUNDED FOLLOWING) AS deriv FROM nnd;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2558: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc55ac4 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2577: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc548b8 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc54135 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000003bc128d7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d009bfb 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3285: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037c3e8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:46:40.216334 [ 5287 ] {} TCPHandler: Code: 43. DB::Exception: The INTERVAL must be a week or shorter, 'IntervalMonth' given. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2558: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc55ac4 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2577: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc548b8 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc54135 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000003bc128d7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d009bfb 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3285: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037c3e8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:46:40.252773 [ 5287 ] {bc8f85ee-248a-4cac-998b-f49bd8536258} executeQuery: Code: 43. DB::Exception: The INTERVAL must be a week or shorter, 'IntervalQuarter' given. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43540) (comment: 02346_non_negative_derivative.sql) (query 17, line 53) (in query: -- Quarter SELECT ts, metric, nonNegativeDerivative(metric, ts, INTERVAL 12 QUARTER) OVER (PARTITION BY metric ORDER BY ts, metric ASC Rows BETWEEN UNBOUNDED PRECEDING AND UNBOUNDED FOLLOWING) AS deriv FROM nnd;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2558: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc55ac4 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2577: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc548b8 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc54135 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000003bc128d7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d009bfb 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3285: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037c3e8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:46:40.256222 [ 5287 ] {} TCPHandler: Code: 43. DB::Exception: The INTERVAL must be a week or shorter, 'IntervalQuarter' given. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2558: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc55ac4 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2577: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc548b8 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc54135 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000003bc128d7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d009bfb 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3285: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037c3e8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:46:40.280738 [ 5287 ] {b7130558-6f89-41df-8550-df4e1c4dbec8} executeQuery: Code: 43. DB::Exception: The INTERVAL must be a week or shorter, 'IntervalYear' given. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43540) (comment: 02346_non_negative_derivative.sql) (query 18, line 55) (in query: -- Year SELECT ts, metric, nonNegativeDerivative(metric, ts, INTERVAL 13 YEAR) OVER (PARTITION BY metric ORDER BY ts, metric ASC Rows BETWEEN UNBOUNDED PRECEDING AND UNBOUNDED FOLLOWING) AS deriv FROM nnd;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2558: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc55ac4 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2577: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc548b8 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc54135 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000003bc128d7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d009bfb 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3285: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037c3e8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:46:40.283626 [ 5287 ] {} TCPHandler: Code: 43. DB::Exception: The INTERVAL must be a week or shorter, 'IntervalYear' given. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2558: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc55ac4 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2577: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc548b8 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc54135 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000003bc128d7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d009bfb 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3285: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037c3e8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:46:40.820089 [ 5287 ] {30610da2-20c1-44f7-8e3c-71e88c8725dc} executeQuery: Code: 36. DB::Exception: Argument 1 must be DateTime or DateTime64, 'UInt8' given. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43540) (comment: 02346_non_negative_derivative.sql) (query 19, line 58) (in query: -- test against wrong arguments/types SELECT ts, metric, nonNegativeDerivative(metric, 1, INTERVAL 3 NANOSECOND) OVER (PARTITION BY metric ORDER BY ts, metric ASC Rows BETWEEN UNBOUNDED PRECEDING AND UNBOUNDED FOLLOWING) AS deriv FROM nnd;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000000ebc964d 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2533: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc558af 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2577: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc548b8 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc54135 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000003bc128d7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d009bfb 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3285: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037c3e8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:46:40.839675 [ 5287 ] {} TCPHandler: Code: 36. DB::Exception: Argument 1 must be DateTime or DateTime64, 'UInt8' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000000ebc964d 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2533: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc558af 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2577: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc548b8 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc54135 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000003bc128d7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d009bfb 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3285: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037c3e8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:46:41.408989 [ 5287 ] {9b21a34c-2b62-497c-ae90-5025c9abe600} executeQuery: Code: 36. DB::Exception: Argument 0 must be a number, 'String' given. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43540) (comment: 02346_non_negative_derivative.sql) (query 20, line 60) (in query: SELECT ts, metric, nonNegativeDerivative('string not datetime', ts, INTERVAL 3 NANOSECOND) OVER (PARTITION BY metric ORDER BY ts, metric ASC Rows BETWEEN UNBOUNDED PRECEDING AND UNBOUNDED FOLLOWING) AS deriv FROM nnd;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000000ebc964d 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2525: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc554bd 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2577: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc548b8 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc54135 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000003bc128d7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d009bfb 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3285: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037c3e8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:46:41.424017 [ 5287 ] {} TCPHandler: Code: 36. DB::Exception: Argument 0 must be a number, 'String' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000000ebc964d 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2525: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc554bd 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2577: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc548b8 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc54135 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000003bc128d7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d009bfb 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3285: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037c3e8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:46:42.498385 [ 5287 ] {31cd6e4e-9404-44ef-a4f5-a61495fdfd51} executeQuery: Code: 42. DB::Exception: Function nonNegativeDerivative takes 2 or 3 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43540) (comment: 02346_non_negative_derivative.sql) (query 21, line 61) (in query: SELECT ts, metric, nonNegativeDerivative(metric, ts, INTERVAL 3 NANOSECOND, id) OVER (PARTITION BY metric ORDER BY ts, metric ASC Rows BETWEEN UNBOUNDED PRECEDING AND UNBOUNDED FOLLOWING) AS deriv FROM nnd;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2519: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc552c1 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2577: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc548b8 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc54135 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000003bc128d7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d009bfb 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3285: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037c3e8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:46:42.501706 [ 5287 ] {} TCPHandler: Code: 42. DB::Exception: Function nonNegativeDerivative takes 2 or 3 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2519: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc552c1 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2577: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc548b8 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc54135 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000003bc128d7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d009bfb 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3285: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037c3e8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:46:42.529144 [ 5287 ] {1bdf32f4-fbd2-4ef4-a35a-f0cbd3622f2d} executeQuery: Code: 42. DB::Exception: Function nonNegativeDerivative takes 2 or 3 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43540) (comment: 02346_non_negative_derivative.sql) (query 22, line 62) (in query: SELECT ts, metric, nonNegativeDerivative(metric) OVER (PARTITION BY metric ORDER BY ts, metric ASC Rows BETWEEN UNBOUNDED PRECEDING AND UNBOUNDED FOLLOWING) AS deriv FROM nnd;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2519: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc552c1 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2577: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc548b8 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc54135 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000003bc128d7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d009bfb 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3285: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037c3e8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:46:42.532148 [ 5287 ] {} TCPHandler: Code: 42. DB::Exception: Function nonNegativeDerivative takes 2 or 3 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2519: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc552c1 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2577: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc548b8 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bc54135 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000003bc128d7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d009bfb 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3285: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037c3e8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:46:45.911069 [ 4332 ] {28c83e84-9d96-4694-96b0-0656480b2574} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35546) (comment: 00754_distributed_optimize_skip_select_on_unused_shards.sh) (query 1, line 1) (in query: SELECT count(*) FROM distributed;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038e302d6 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000003aa3ce49 4. ./build_docker/./src/Client/HedgedConnections.cpp:67: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000003aa19828 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002f204e76 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002f1e75e7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f1cc5c0 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f23f0fe 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 2025.06.13 08:46:45.921208 [ 9246 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:35558, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fbc2c6f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fbc3c01 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9b2eba 6. DB::ReadBuffer::next() @ 0x0000000008e83ccf 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003ad8c853 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:46:45.921664 [ 9246 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:35558, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fbc2c6f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fbc3c01 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9b2eba 6. DB::ReadBuffer::next() @ 0x0000000008e83ccf 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003ad8c853 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:46:45.938126 [ 4332 ] {} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038e302d6 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000003aa3ce49 4. ./build_docker/./src/Client/HedgedConnections.cpp:67: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000003aa19828 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002f204e76 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002f1e75e7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f1cc5c0 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f23f0fe 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:46:46.966162 [ 2141 ] {d9338ebb-e685-47cd-bf42-d73ee7e62157} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35574) (comment: 00754_distributed_optimize_skip_select_on_unused_shards.sh) (query 1, line 1) (in query: SELECT count(*) FROM distributed WHERE a = 0 AND b = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038e302d6 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000003aa3ce49 4. ./build_docker/./src/Client/HedgedConnections.cpp:67: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000003aa19828 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002f204e76 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002f1e75e7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f1cc5c0 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f23f0fe 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 2025.06.13 08:46:46.998493 [ 2141 ] {} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038e302d6 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000003aa3ce49 4. ./build_docker/./src/Client/HedgedConnections.cpp:67: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000003aa19828 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002f204e76 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002f1e75e7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f1cc5c0 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f23f0fe 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:46:47.245634 [ 9230 ] {c7c3b147-16ba-40ef-91f6-b2bb781aa165} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:35596). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe68d 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:46:47.247713 [ 9230 ] {c7c3b147-16ba-40ef-91f6-b2bb781aa165} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:35596). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35596) (comment: 00754_distributed_optimize_skip_select_on_unused_shards.sh) (query 1, line 1) (in query: SELECT count() AS `count()` FROM `test_snrwllyx`.`mergetree_00754` AS `__table1` WHERE (`__table1`.`a` = 0) AND (`__table1`.`b` = 0)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe68d 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:46:47.253430 [ 9230 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:35596). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe68d 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:46:49.087830 [ 9236 ] {654d7740-dbf3-426b-a96f-0c4c239c7567} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35662) (comment: 00754_distributed_optimize_skip_select_on_unused_shards.sh) (query 2, line 3) (in query: SELECT count(*) FROM distributed WHERE a = 2 AND b = 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038e302d6 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000003aa3ce49 4. ./build_docker/./src/Client/HedgedConnections.cpp:67: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000003aa19828 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002f204e76 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002f1e75e7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f1cc5c0 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f23f0fe 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 2025.06.13 08:46:49.111281 [ 9236 ] {} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038e302d6 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000003aa3ce49 4. ./build_docker/./src/Client/HedgedConnections.cpp:67: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000003aa19828 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002f204e76 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002f1e75e7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f1cc5c0 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f23f0fe 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:46:54.413300 [ 4332 ] {729ebf3c-8b5f-4e4e-954d-78e9966694ff} executeQuery: Code: 44. DB::Exception: Trying to set TTL for key column d. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35584) (comment: 00933_ttl_simple.sql) (query 64, line 105) (in query: create table ttl_00933_1 (d DateTime ttl d) engine = MergeTree order by tuple() partition by toSecond(d);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1013: DB::MergeTreeData::checkTTLExpressions(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&) const @ 0x000000003976b116 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:530: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000003975c7c0 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a38dc5f 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a38d037 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37f002 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:46:54.417146 [ 4332 ] {} TCPHandler: Code: 44. DB::Exception: Trying to set TTL for key column d. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1013: DB::MergeTreeData::checkTTLExpressions(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&) const @ 0x000000003976b116 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:530: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000003975c7c0 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a38dc5f 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a38d037 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37f002 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:46:54.473518 [ 4332 ] {4ce54926-2c64-4c78-80ea-959d1d1d16de} executeQuery: Code: 44. DB::Exception: Trying to set TTL for key column a. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35584) (comment: 00933_ttl_simple.sql) (query 65, line 106) (in query: create table ttl_00933_1 (d DateTime, a Int ttl d) engine = MergeTree order by a partition by toSecond(d);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1013: DB::MergeTreeData::checkTTLExpressions(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&) const @ 0x000000003976b116 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:530: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000003975c7c0 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a38dc5f 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a38d037 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37f002 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:46:54.476212 [ 4332 ] {} TCPHandler: Code: 44. DB::Exception: Trying to set TTL for key column a. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1013: DB::MergeTreeData::checkTTLExpressions(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&) const @ 0x000000003976b116 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:530: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000003975c7c0 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a38dc5f 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a38d037 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37f002 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:46:54.715549 [ 4332 ] {d863d4d3-9757-4b90-a6d8-dc9fa73a74eb} executeQuery: Code: 450. DB::Exception: TTL expression result column should have DateTime or Date type, but has UInt16. (BAD_TTL_EXPRESSION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35584) (comment: 00933_ttl_simple.sql) (query 66, line 107) (in query: create table ttl_00933_1 (d DateTime, a Int ttl 2 + 2) engine = MergeTree order by tuple() partition by toSecond(d);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/TTLDescription.cpp:95: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x0000000038dc1ba3 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:772: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37d80e 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:46:54.718831 [ 4332 ] {} TCPHandler: Code: 450. DB::Exception: TTL expression result column should have DateTime or Date type, but has UInt16. (BAD_TTL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/TTLDescription.cpp:95: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x0000000038dc1ba3 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:772: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37d80e 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:46:54.784478 [ 4332 ] {2b1a6629-9c7e-46f4-b279-a11372a174e4} executeQuery: Code: 450. DB::Exception: TTL expression result column should have DateTime or Date type, but has Int32. (BAD_TTL_EXPRESSION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35584) (comment: 00933_ttl_simple.sql) (query 67, line 108) (in query: create table ttl_00933_1 (d DateTime, a Int ttl d - d) engine = MergeTree order by tuple() partition by toSecond(d);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/TTLDescription.cpp:95: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x0000000038dc1ba3 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:772: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37d80e 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:46:54.788574 [ 4332 ] {} TCPHandler: Code: 450. DB::Exception: TTL expression result column should have DateTime or Date type, but has Int32. (BAD_TTL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/TTLDescription.cpp:95: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x0000000038dc1ba3 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:772: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37d80e 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:46:54.812090 [ 9234 ] {13ab1d2a-cccc-4502-bbd0-1c3a837d41ec} executeQuery: Code: 344. DB::Exception: DELETE query is not allowed for table test_kk53vpwd.t_proj because as it has projections and setting lightweight_mutation_projection_mode is set to THROW. User should change lightweight_mutation_projection_mode OR drop all the projections manually before running the query. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35528) (comment: 02319_lightweight_delete_on_merge_tree.sql) (query 66, line 105) (in query: DELETE FROM t_proj WHERE a < 100;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:113: DB::InterpreterDeleteQuery::execute() @ 0x00000000338f2249 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 7. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:46:54.823161 [ 9234 ] {} TCPHandler: Code: 344. DB::Exception: DELETE query is not allowed for table test_kk53vpwd.t_proj because as it has projections and setting lightweight_mutation_projection_mode is set to THROW. User should change lightweight_mutation_projection_mode OR drop all the projections manually before running the query. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:113: DB::InterpreterDeleteQuery::execute() @ 0x00000000338f2249 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 7. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:46:55.038488 [ 4332 ] {d3368f35-f6d1-4798-95ce-5505d155b880} executeQuery: Code: 36. DB::Exception: Engine Log doesn't support TTL clause. Currently only the following engines have support for the feature: [ReplicatedSummingMergeTree, ReplicatedVersionedCollapsingMergeTree, VersionedCollapsingMergeTree, ReplacingMergeTree, EmbeddedRocksDB, ReplicatedCollapsingMergeTree, ReplicatedGraphiteMergeTree, ReplicatedMergeTree, ReplicatedReplacingMergeTree, SummingMergeTree, MergeTree, GraphiteMergeTree, CollapsingMergeTree, ReplicatedAggregatingMergeTree, AggregatingMergeTree]. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35584) (comment: 00933_ttl_simple.sql) (query 68, line 110) (in query: create table ttl_00933_1 (d DateTime, a Int ttl d + interval 1 day) engine = Log;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&) @ 0x000000002009adf7 4. ./build_docker/./src/Storages/StorageFactory.cpp:187: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const::$_0::operator()(String, std::function) const @ 0x00000000383eb343 5. ./build_docker/./src/Storages/StorageFactory.cpp:204: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000383e8c11 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:46:55.041931 [ 4332 ] {} TCPHandler: Code: 36. DB::Exception: Engine Log doesn't support TTL clause. Currently only the following engines have support for the feature: [ReplicatedSummingMergeTree, ReplicatedVersionedCollapsingMergeTree, VersionedCollapsingMergeTree, ReplacingMergeTree, EmbeddedRocksDB, ReplicatedCollapsingMergeTree, ReplicatedGraphiteMergeTree, ReplicatedMergeTree, ReplicatedReplacingMergeTree, SummingMergeTree, MergeTree, GraphiteMergeTree, CollapsingMergeTree, ReplicatedAggregatingMergeTree, AggregatingMergeTree]. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&) @ 0x000000002009adf7 4. ./build_docker/./src/Storages/StorageFactory.cpp:187: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const::$_0::operator()(String, std::function) const @ 0x00000000383eb343 5. ./build_docker/./src/Storages/StorageFactory.cpp:204: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000383e8c11 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:46:55.062345 [ 4332 ] {65ffc710-984a-45ce-83ae-8bddcb8233d4} executeQuery: Code: 36. DB::Exception: Engine Log doesn't support TTL clause. Currently only the following engines have support for the feature: [ReplicatedSummingMergeTree, ReplicatedVersionedCollapsingMergeTree, VersionedCollapsingMergeTree, ReplacingMergeTree, EmbeddedRocksDB, ReplicatedCollapsingMergeTree, ReplicatedGraphiteMergeTree, ReplicatedMergeTree, ReplicatedReplacingMergeTree, SummingMergeTree, MergeTree, GraphiteMergeTree, CollapsingMergeTree, ReplicatedAggregatingMergeTree, AggregatingMergeTree]. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35584) (comment: 00933_ttl_simple.sql) (query 69, line 111) (in query: create table ttl_00933_1 (d DateTime, a Int) engine = Log ttl d + interval 1 day;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&) @ 0x000000002009adf7 4. ./build_docker/./src/Storages/StorageFactory.cpp:187: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const::$_0::operator()(String, std::function) const @ 0x00000000383eb343 5. ./build_docker/./src/Storages/StorageFactory.cpp:204: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000383e8c11 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:46:55.065965 [ 4332 ] {} TCPHandler: Code: 36. DB::Exception: Engine Log doesn't support TTL clause. Currently only the following engines have support for the feature: [ReplicatedSummingMergeTree, ReplicatedVersionedCollapsingMergeTree, VersionedCollapsingMergeTree, ReplacingMergeTree, EmbeddedRocksDB, ReplicatedCollapsingMergeTree, ReplicatedGraphiteMergeTree, ReplicatedMergeTree, ReplicatedReplacingMergeTree, SummingMergeTree, MergeTree, GraphiteMergeTree, CollapsingMergeTree, ReplicatedAggregatingMergeTree, AggregatingMergeTree]. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&) @ 0x000000002009adf7 4. ./build_docker/./src/Storages/StorageFactory.cpp:187: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const::$_0::operator()(String, std::function) const @ 0x00000000383eb343 5. ./build_docker/./src/Storages/StorageFactory.cpp:204: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000383e8c11 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:46:55.193464 [ 9234 ] {323faeab-fbe9-4b3f-9261-a810d2a0791c} executeQuery: Code: 344. DB::Exception: Lightweight delete mutate is disabled. Set `enable_lightweight_delete` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35528) (comment: 02319_lightweight_delete_on_merge_tree.sql) (query 71, line 113) (in query: DELETE FROM merge_table_standard_delete WHERE id = 10;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:105: DB::InterpreterDeleteQuery::execute() @ 0x00000000338f1ca2 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 7. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:46:55.195881 [ 9234 ] {} TCPHandler: Code: 344. DB::Exception: Lightweight delete mutate is disabled. Set `enable_lightweight_delete` setting to enable it. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:105: DB::InterpreterDeleteQuery::execute() @ 0x00000000338f1ca2 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 7. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:46:55.229875 [ 9234 ] {1edb8644-efb1-4554-8bc6-4617aeaa7b03} executeQuery: Code: 344. DB::Exception: Lightweight delete mutate is disabled. Set `enable_lightweight_delete` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35528) (comment: 02319_lightweight_delete_on_merge_tree.sql) (query 73, line 115) (in query: DELETE FROM merge_table_standard_delete WHERE id = 10;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:105: DB::InterpreterDeleteQuery::execute() @ 0x00000000338f1ca2 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 7. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:46:55.232563 [ 9234 ] {} TCPHandler: Code: 344. DB::Exception: Lightweight delete mutate is disabled. Set `enable_lightweight_delete` setting to enable it. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:105: DB::InterpreterDeleteQuery::execute() @ 0x00000000338f1ca2 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 7. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:46:57.502469 [ 9230 ] {1fe611b9-ed06-40fa-ad2a-94ec5f6f6f4e} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 333.83 MiB (attempt to allocate chunk of 48.06 MiB bytes), maximum: 300.00 MiB.: While executing FillingRightJoinSide. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35660) (comment: 03277_join_adaptive_spill_oom.sql) (query 13, line 18) (in query: select t1.k, t2.x, t3.x from adaptive_spill_03277_1 as t1 left join adaptive_spill_03277_2 as t2 on t1.k = t2.k left join adaptive_spill_03277_3 as t3 on t1.k = t3.k Format Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f53f624 8. ./src/Common/HashTable/HashTable.h:538: HashTable, HashTableNoState>, DefaultHash, HashTableGrowerWithPrecalculation<8ul>, Allocator>::resize(unsigned long, unsigned long) @ 0x000000003401e64f 9. ./src/Common/HashTable/HashTable.h:926: void DB::HashJoinMethods<(DB::JoinKind)1, (DB::JoinStrictness)3, DB::HashJoin::MapsTemplate>::insertFromBlockImplTypeCase, DB::RowRefList, true, false, true, false>, HashMapTable, HashTableNoState>, DefaultHash, HashTableGrowerWithPrecalculation<8ul>, Allocator>, std::pair>(DB::HashJoin&, HashMapTable, HashTableNoState>, DefaultHash, HashTableGrowerWithPrecalculation<8ul>, Allocator>&, std::vector> const&, std::vector> const&, DB::Block const*, std::pair const&, DB::PODArray, 63ul, 64ul> const*, DB::PODArray, 63ul, 64ul> const*, DB::Arena&, bool&) @ 0x00000000354cbcee 10. ./src/Interpreters/HashJoin/HashJoinMethodsImpl.h:51: DB::HashJoinMethods<(DB::JoinKind)1, (DB::JoinStrictness)3, DB::HashJoin::MapsTemplate>::insertFromBlockImpl(DB::HashJoin&, DB::HashJoin::Type, DB::HashJoin::MapsTemplate&, std::vector> const&, std::vector> const&, DB::Block const*, DB::detail::Selector const&, DB::PODArray, 63ul, 64ul> const*, DB::PODArray, 63ul, 64ul> const*, DB::Arena&, bool&) @ 0x00000000354c3091 11. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:717: DB::HashJoin::addBlockToJoin(DB::ScatteredBlock&, bool) @ 0x0000000033ad5fb6 12. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:553: DB::HashJoin::addBlockToJoin(DB::Block const&, bool) @ 0x0000000033acb265 13. ./build_docker/./src/Interpreters/GraceHashJoin.cpp:722: DB::GraceHashJoin::addBlockToJoinImpl(DB::Block) @ 0x0000000032843216 14. ./build_docker/./src/Interpreters/GraceHashJoin.cpp:307: DB::GraceHashJoin::addBlockToJoin(DB::Block const&, bool) @ 0x00000000328402a4 15. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:357: DB::FillingRightJoinSideTransform::work() @ 0x000000003ba38038 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:46:57.603971 [ 9230 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 333.83 MiB (attempt to allocate chunk of 48.06 MiB bytes), maximum: 300.00 MiB.: While executing FillingRightJoinSide. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f53f624 8. ./src/Common/HashTable/HashTable.h:538: HashTable, HashTableNoState>, DefaultHash, HashTableGrowerWithPrecalculation<8ul>, Allocator>::resize(unsigned long, unsigned long) @ 0x000000003401e64f 9. ./src/Common/HashTable/HashTable.h:926: void DB::HashJoinMethods<(DB::JoinKind)1, (DB::JoinStrictness)3, DB::HashJoin::MapsTemplate>::insertFromBlockImplTypeCase, DB::RowRefList, true, false, true, false>, HashMapTable, HashTableNoState>, DefaultHash, HashTableGrowerWithPrecalculation<8ul>, Allocator>, std::pair>(DB::HashJoin&, HashMapTable, HashTableNoState>, DefaultHash, HashTableGrowerWithPrecalculation<8ul>, Allocator>&, std::vector> const&, std::vector> const&, DB::Block const*, std::pair const&, DB::PODArray, 63ul, 64ul> const*, DB::PODArray, 63ul, 64ul> const*, DB::Arena&, bool&) @ 0x00000000354cbcee 10. ./src/Interpreters/HashJoin/HashJoinMethodsImpl.h:51: DB::HashJoinMethods<(DB::JoinKind)1, (DB::JoinStrictness)3, DB::HashJoin::MapsTemplate>::insertFromBlockImpl(DB::HashJoin&, DB::HashJoin::Type, DB::HashJoin::MapsTemplate&, std::vector> const&, std::vector> const&, DB::Block const*, DB::detail::Selector const&, DB::PODArray, 63ul, 64ul> const*, DB::PODArray, 63ul, 64ul> const*, DB::Arena&, bool&) @ 0x00000000354c3091 11. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:717: DB::HashJoin::addBlockToJoin(DB::ScatteredBlock&, bool) @ 0x0000000033ad5fb6 12. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:553: DB::HashJoin::addBlockToJoin(DB::Block const&, bool) @ 0x0000000033acb265 13. ./build_docker/./src/Interpreters/GraceHashJoin.cpp:722: DB::GraceHashJoin::addBlockToJoinImpl(DB::Block) @ 0x0000000032843216 14. ./build_docker/./src/Interpreters/GraceHashJoin.cpp:307: DB::GraceHashJoin::addBlockToJoin(DB::Block const&, bool) @ 0x00000000328402a4 15. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:357: DB::FillingRightJoinSideTransform::work() @ 0x000000003ba38038 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:46:58.026483 [ 2133 ] {9651ec6e-4996-4616-8588-6684b2bde0e5} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40626) (comment: 00754_distributed_optimize_skip_select_on_unused_shards.sh) (query 2, line 3) (in query: SELECT count(*) FROM distributed WHERE a = 0 AND b <= 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038e302d6 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000003aa3ce49 4. ./build_docker/./src/Client/HedgedConnections.cpp:67: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000003aa19828 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002f204e76 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002f1e75e7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f1cc5c0 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f23f0fe 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 2025.06.13 08:46:58.041561 [ 2133 ] {} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038e302d6 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000003aa3ce49 4. ./build_docker/./src/Client/HedgedConnections.cpp:67: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000003aa19828 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002f204e76 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002f1e75e7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f1cc5c0 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f23f0fe 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:46:58.091026 [ 9246 ] {016752f7-48be-4d39-b6fc-be3e005620ca} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:35630). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe68d 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:46:58.092695 [ 9246 ] {016752f7-48be-4d39-b6fc-be3e005620ca} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:35630). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35630) (comment: 00754_distributed_optimize_skip_select_on_unused_shards.sh) (query 2, line 3) (in query: SELECT count() AS `count()` FROM `test_snrwllyx`.`mergetree_00754` AS `__table1` WHERE (`__table1`.`a` = 0) AND (`__table1`.`b` <= 1)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe68d 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:46:58.097100 [ 9246 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:35630). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe68d 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:46:59.126915 [ 4330 ] {1b4270ef-f4bd-493d-b850-0804032140e0} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40636) (comment: 00754_distributed_optimize_skip_select_on_unused_shards.sh) (query 2, line 3) (in query: SELECT count(*) FROM distributed WHERE a = 0 AND c = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038e302d6 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000003aa3ce49 4. ./build_docker/./src/Client/HedgedConnections.cpp:67: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000003aa19828 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002f204e76 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002f1e75e7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f1cc5c0 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f23f0fe 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 2025.06.13 08:46:59.144559 [ 4330 ] {} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038e302d6 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000003aa3ce49 4. ./build_docker/./src/Client/HedgedConnections.cpp:67: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000003aa19828 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002f204e76 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002f1e75e7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f1cc5c0 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f23f0fe 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:46:59.215311 [ 5281 ] {e4886f6a-5c3b-4598-aa13-56095d901492} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:40650). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe68d 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:46:59.218502 [ 5281 ] {e4886f6a-5c3b-4598-aa13-56095d901492} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:40650). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40650) (comment: 00754_distributed_optimize_skip_select_on_unused_shards.sh) (query 2, line 3) (in query: SELECT count() AS `count()` FROM `test_snrwllyx`.`mergetree_00754` AS `__table1` WHERE (`__table1`.`a` = 0) AND (`__table1`.`c` = 0)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe68d 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:46:59.230009 [ 5281 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:40650). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe68d 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:47:00.166422 [ 5287 ] {9becd47e-28d5-4c46-975d-a3b710f9d461} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40674) (comment: 00754_distributed_optimize_skip_select_on_unused_shards.sh) (query 2, line 3) (in query: SELECT count(*) FROM distributed WHERE a = 0 OR a = 1 AND b = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038e302d6 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000003aa3ce49 4. ./build_docker/./src/Client/HedgedConnections.cpp:67: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000003aa19828 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002f204e76 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002f1e75e7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f1cc5c0 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f23f0fe 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 2025.06.13 08:47:00.179378 [ 5287 ] {} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038e302d6 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000003aa3ce49 4. ./build_docker/./src/Client/HedgedConnections.cpp:67: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000003aa19828 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002f204e76 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002f1e75e7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f1cc5c0 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f23f0fe 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:47:00.228493 [ 4330 ] {6bcb9a73-5770-421e-b10d-043260358c6b} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:40690). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe68d 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:47:00.230278 [ 4330 ] {6bcb9a73-5770-421e-b10d-043260358c6b} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:40690). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40690) (comment: 00754_distributed_optimize_skip_select_on_unused_shards.sh) (query 2, line 3) (in query: SELECT count() AS `count()` FROM `test_snrwllyx`.`mergetree_00754` AS `__table1` WHERE (`__table1`.`a` = 0) OR ((`__table1`.`a` = 1) AND (`__table1`.`b` = 0))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe68d 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:47:00.234622 [ 4330 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:40690). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe68d 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:47:01.205169 [ 2084 ] {9b389b28-bf20-4200-819a-da375d23f7fe} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40708) (comment: 00754_distributed_optimize_skip_select_on_unused_shards.sh) (query 2, line 3) (in query: SELECT count(*) FROM distributed WHERE a = 0 AND b = 0 OR a = 2 AND b = 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038e302d6 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000003aa3ce49 4. ./build_docker/./src/Client/HedgedConnections.cpp:67: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000003aa19828 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002f204e76 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002f1e75e7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f1cc5c0 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f23f0fe 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 2025.06.13 08:47:01.219912 [ 2084 ] {} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038e302d6 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000003aa3ce49 4. ./build_docker/./src/Client/HedgedConnections.cpp:67: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000003aa19828 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002f204e76 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002f1e75e7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f1cc5c0 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f23f0fe 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:47:01.260425 [ 9215 ] {a1f95da6-d148-48af-ae60-6603f6b0a028} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:40718). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe68d 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:47:01.262088 [ 9215 ] {a1f95da6-d148-48af-ae60-6603f6b0a028} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:40718). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40718) (comment: 00754_distributed_optimize_skip_select_on_unused_shards.sh) (query 2, line 3) (in query: SELECT count() AS `count()` FROM `test_snrwllyx`.`mergetree_00754` AS `__table1` WHERE ((`__table1`.`a` = 0) AND (`__table1`.`b` = 0)) OR ((`__table1`.`a` = 2) AND (`__table1`.`b` = 2))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe68d 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:47:01.267665 [ 9215 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:40718). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe68d 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:47:02.218142 [ 5281 ] {9e3f7909-da87-47f4-bda0-11be01dc35cd} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40732) (comment: 00754_distributed_optimize_skip_select_on_unused_shards.sh) (query 2, line 3) (in query: SELECT count(*) FROM distributed WHERE a = 0 AND b = 0 OR c = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038e302d6 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000003aa3ce49 4. ./build_docker/./src/Client/HedgedConnections.cpp:67: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000003aa19828 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002f204e76 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002f1e75e7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f1cc5c0 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f23f0fe 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 2025.06.13 08:47:02.231750 [ 5281 ] {} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038e302d6 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000003aa3ce49 4. ./build_docker/./src/Client/HedgedConnections.cpp:67: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000003aa19828 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002f204e76 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002f1e75e7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f1cc5c0 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f23f0fe 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:47:02.303603 [ 9215 ] {d72f5e47-e519-4fac-b9fc-614fe69dd445} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:40740). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe68d 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:47:02.305141 [ 9215 ] {d72f5e47-e519-4fac-b9fc-614fe69dd445} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:40740). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40740) (comment: 00754_distributed_optimize_skip_select_on_unused_shards.sh) (query 2, line 3) (in query: SELECT count() AS `count()` FROM `test_snrwllyx`.`mergetree_00754` AS `__table1` WHERE ((`__table1`.`a` = 0) AND (`__table1`.`b` = 0)) OR (`__table1`.`c` = 0)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe68d 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:47:02.309661 [ 9215 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:40740). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe68d 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:47:03.802934 [ 5281 ] {7e5c7e26-c570-4e7a-a735-ec891f3cf2bd} executeQuery: Code: 628. DB::Exception: Can not use OFFSET FETCH clause without ORDER BY. (OFFSET_FETCH_WITHOUT_ORDER_BY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48272) (comment: 02114_offset_fetch_without_order_by.sh) (in query: SELECT number from numbers(10) OFFSET 1 ROWS FETCH FIRST 1 ROWS ONLY;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Parsers/ParserSelectQuery.cpp:430: DB::ParserSelectQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e13bd82 5. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 6. ./build_docker/./src/Parsers/ParserUnionQueryElement.cpp:13: DB::ParserUnionQueryElement::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e191284 7. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 8. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:82: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x000000003e00ed2c 9. ./src/Parsers/ExpressionListParsers.h:89: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003dfeeb70 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 11. ./build_docker/./src/Parsers/ParserSelectWithUnionQuery.cpp:15: DB::ParserSelectWithUnionQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e13dc91 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 13. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:74: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e105bc7 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 15. ./build_docker/./src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e0ef822 16. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 17. ./build_docker/./src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x000000003e1c2b33 18. ./build_docker/./src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003e1c5b90 19. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003e1c5ed1 20. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033726084 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 22. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 23. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 24. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 08:47:03.805955 [ 5281 ] {7e5c7e26-c570-4e7a-a735-ec891f3cf2bd} DynamicQueryHandler: Code: 628. DB::Exception: Can not use OFFSET FETCH clause without ORDER BY. (OFFSET_FETCH_WITHOUT_ORDER_BY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Parsers/ParserSelectQuery.cpp:430: DB::ParserSelectQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e13bd82 5. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 6. ./build_docker/./src/Parsers/ParserUnionQueryElement.cpp:13: DB::ParserUnionQueryElement::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e191284 7. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 8. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:82: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x000000003e00ed2c 9. ./src/Parsers/ExpressionListParsers.h:89: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003dfeeb70 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 11. ./build_docker/./src/Parsers/ParserSelectWithUnionQuery.cpp:15: DB::ParserSelectWithUnionQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e13dc91 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 13. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:74: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e105bc7 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 15. ./build_docker/./src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e0ef822 16. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 17. ./build_docker/./src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x000000003e1c2b33 18. ./build_docker/./src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003e1c5b90 19. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003e1c5ed1 20. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033726084 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 22. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 23. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 24. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:47:08.206752 [ 9235 ] {2994fab1-f437-4ab0-96d8-7b0cd7f9532d} executeQuery: Code: 137. DB::Exception: test_l2gh5kxw.id_value_dictionary: unknown dictionary source type: clickhousex. (UNKNOWN_ELEMENT_IN_CONFIG) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59952) (comment: 02918_wrong_dictionary_source.sql) (query 4, line 6) (in query: -- There is no "CLICKHOUSEX" dictionary source, so the next query must fail even if `dictionaries_lazy_load` is enabled. CREATE DICTIONARY id_value_dictionary(id UInt64, value String) PRIMARY KEY id SOURCE(CLICKHOUSEX(TABLE 'source_table')) LIFETIME(MIN 0 MAX 1000) LAYOUT(FLAT());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000008bb626d 4. ./build_docker/./src/Dictionaries/DictionarySourceFactory.cpp:116: DB::DictionarySourceFactory::checkSourceAvailable(String const&, String const&, std::shared_ptr const&) const @ 0x000000002bfceb32 5. ./build_docker/./src/Dictionaries/getDictionaryConfigurationFromAST.cpp:539: DB::getDictionaryConfigurationFromAST(DB::ASTCreateQuery const&, std::shared_ptr, String const&) @ 0x000000002f7ca04a 6. ./build_docker/./src/Storages/StorageDictionary.cpp:351: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000038345dfc 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:47:08.209667 [ 9235 ] {} TCPHandler: Code: 137. DB::Exception: test_l2gh5kxw.id_value_dictionary: unknown dictionary source type: clickhousex. (UNKNOWN_ELEMENT_IN_CONFIG), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000008bb626d 4. ./build_docker/./src/Dictionaries/DictionarySourceFactory.cpp:116: DB::DictionarySourceFactory::checkSourceAvailable(String const&, String const&, std::shared_ptr const&) const @ 0x000000002bfceb32 5. ./build_docker/./src/Dictionaries/getDictionaryConfigurationFromAST.cpp:539: DB::getDictionaryConfigurationFromAST(DB::ASTCreateQuery const&, std::shared_ptr, String const&) @ 0x000000002f7ca04a 6. ./build_docker/./src/Storages/StorageDictionary.cpp:351: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000038345dfc 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:47:09.656168 [ 9235 ] {83cb2081-30a6-4e59-a140-efe0eb45a8ae} executeQuery: Code: 43. DB::Exception: Illegal type of argument 'structure' for table function 'executable': must be an identifier or string literal, but got: max_command_execution_time = 100. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59984) (comment: 02377_executable_function_settings.sql) (query 7, line 8) (in query: SELECT * from executable('JSON', 'data String', SETTINGS max_command_execution_time=100);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x00000000266069d7 4. ./build_docker/./src/TableFunctions/TableFunctionExecutable.cpp:109: DB::(anonymous namespace)::TableFunctionExecutable::parseArguments(std::shared_ptr const&, std::shared_ptr)::$_1::operator()(unsigned long, String const&) const @ 0x0000000026605ca6 5. ./build_docker/./src/TableFunctions/TableFunctionExecutable.cpp:116: DB::(anonymous namespace)::TableFunctionExecutable::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000265fdf06 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:47:09.658818 [ 9235 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type of argument 'structure' for table function 'executable': must be an identifier or string literal, but got: max_command_execution_time = 100. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x00000000266069d7 4. ./build_docker/./src/TableFunctions/TableFunctionExecutable.cpp:109: DB::(anonymous namespace)::TableFunctionExecutable::parseArguments(std::shared_ptr const&, std::shared_ptr)::$_1::operator()(unsigned long, String const&) const @ 0x0000000026605ca6 5. ./build_docker/./src/TableFunctions/TableFunctionExecutable.cpp:116: DB::(anonymous namespace)::TableFunctionExecutable::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000265fdf06 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:47:09.862256 [ 9235 ] {c94d7448-b112-4517-9835-448724c01370} executeQuery: Code: 36. DB::Exception: Table function 'executable' argument is invalid 'TEST'. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59984) (comment: 02377_executable_function_settings.sql) (query 8, line 9) (in query: SELECT * from executable('JSON', 'data String', 'TEST', 'TEST');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/TableFunctions/TableFunctionExecutable.cpp:150: DB::(anonymous namespace)::TableFunctionExecutable::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000026601f33 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:47:09.864613 [ 9235 ] {} TCPHandler: Code: 36. DB::Exception: Table function 'executable' argument is invalid 'TEST'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/TableFunctions/TableFunctionExecutable.cpp:150: DB::(anonymous namespace)::TableFunctionExecutable::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000026601f33 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:47:11.313469 [ 9247 ] {23346993-4d78-42f2-b7b9-57a6649fb3a5} executeQuery: Code: 122. DB::Exception: Data in Object has ambiguous paths: 'key_0.key_11' and 'key_0.key_5'. Paths have prefixes matched by names, but different in structure. (INCOMPATIBLE_COLUMNS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60024) (comment: 01825_type_json_14.sql) (query 6, line 10) (in query: INSERT INTO t_json_14 VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000008bb626d 4. ./build_docker/./src/DataTypes/ObjectUtils.cpp:336: DB::checkObjectHasNoAmbiguosPaths(std::vector> const&) @ 0x000000002f439830 5. ./build_docker/./src/DataTypes/ObjectUtils.cpp:393: DB::getLeastCommonTypeForDynamicColumnsImpl(std::shared_ptr const&, std::vector, std::allocator>> const&, bool) @ 0x000000002f43cbb6 6. ./build_docker/./src/DataTypes/ObjectUtils.cpp:489: DB::convertDynamicColumnsToTuples(DB::Block&, std::shared_ptr const&) @ 0x000000002f43593c 7. ./build_docker/./src/Storages/StorageMemory.cpp:88: DB::MemorySink::consume(DB::Chunk&) @ 0x0000000038683dbd 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 15. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b10197a 16. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003adbc219 17. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x000000003ad8e9f8 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:47:11.316962 [ 9247 ] {} TCPHandler: Code: 122. DB::Exception: Data in Object has ambiguous paths: 'key_0.key_11' and 'key_0.key_5'. Paths have prefixes matched by names, but different in structure. (INCOMPATIBLE_COLUMNS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000008bb626d 4. ./build_docker/./src/DataTypes/ObjectUtils.cpp:336: DB::checkObjectHasNoAmbiguosPaths(std::vector> const&) @ 0x000000002f439830 5. ./build_docker/./src/DataTypes/ObjectUtils.cpp:393: DB::getLeastCommonTypeForDynamicColumnsImpl(std::shared_ptr const&, std::vector, std::allocator>> const&, bool) @ 0x000000002f43cbb6 6. ./build_docker/./src/DataTypes/ObjectUtils.cpp:489: DB::convertDynamicColumnsToTuples(DB::Block&, std::shared_ptr const&) @ 0x000000002f43593c 7. ./build_docker/./src/Storages/StorageMemory.cpp:88: DB::MemorySink::consume(DB::Chunk&) @ 0x0000000038683dbd 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 15. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b10197a 16. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003adbc219 17. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x000000003ad8e9f8 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:47:16.588527 [ 3255 ] {96158d3d-7b12-48fb-8e0a-29eabf9c118b} executeQuery: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36600) (comment: 01635_sum_map_fuzz.sql) (query 4, line 5) (in query: SELECT [NULL], sumMapWithOverflow(events, [NULL], [[(NULL)]], counts) FROM sum_map_overflow;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionSumMap.cpp:130: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000023fca125 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d009bfb 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303855f9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 29. ? @ 0x00007f5206343ac3 30. ? @ 0x00007f52063d5850 2025.06.13 08:47:16.591375 [ 3255 ] {} TCPHandler: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionSumMap.cpp:130: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000023fca125 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d009bfb 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303855f9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 29. ? @ 0x00007f5206343ac3 30. ? @ 0x00007f52063d5850 2025.06.13 08:47:18.761591 [ 9257 ] {e98b309d-79a1-400a-b71e-0edbe89941c8} executeQuery: Code: 630. DB::Exception: Cannot drop or rename test_6r1upbq2.Mapping (e46974a6-6831-4e33-a954-bae18e9e10a0), because some tables depend on it: test_6r1upbq2.Sub_distributed. (HAVE_DEPENDENT_OBJECTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36712) (comment: 02916_joinget_dependency.sh) (query 1, line 2) (in query: DROP TABLE Mapping;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x0000000031a48ead 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1553: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x0000000031a2c0df 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1535: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x0000000031a2d676 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:300: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003296e232 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032968e1f 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965c79 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:47:18.765235 [ 9257 ] {} TCPHandler: Code: 630. DB::Exception: Cannot drop or rename test_6r1upbq2.Mapping (e46974a6-6831-4e33-a954-bae18e9e10a0), because some tables depend on it: test_6r1upbq2.Sub_distributed. (HAVE_DEPENDENT_OBJECTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x0000000031a48ead 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1553: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x0000000031a2c0df 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1535: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x0000000031a2d676 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:300: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003296e232 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032968e1f 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965c79 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:47:18.855609 [ 740 ] {} test_yswjsvt0.r1 (ReplicatedMergeTreeCleanupThread): Will mark replica 2r1 as lost, because it has stale log pointer: log-0000000000 2025.06.13 08:47:20.830852 [ 9257 ] {2f06ab05-a762-4817-8a67-928bb09226c3} executeQuery: Code: 28. DB::Exception: Too high precision requested for Float, must not be more than 60, got 61: In scope SELECT toDecimalString(CAST('32.32', 'Float32'), 61). (CANNOT_PRINT_FLOAT_OR_DOUBLE_NUMBER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36764) (comment: 02676_to_decimal_string.sql) (query 22, line 29) (in query: -- Max number of decimal fractional digits is defined as 77 for Int/UInt/Decimal and 60 for Float. -- These values shall work OK. SELECT toDecimalString('32.32'::Float32, 61);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<_BitInt(8)>(int, FormatStringHelperImpl::type>, std::type_identity<_BitInt(8)>&&) @ 0x000000001aa332ea 4. void DB::(anonymous namespace)::FunctionToDecimalString::format(float, DB::WriteBuffer&, char8_t) @ 0x000000001aa31ec6 5. DB::(anonymous namespace)::FunctionToDecimalString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa104ae 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 2025.06.13 08:47:20.835055 [ 9257 ] {} TCPHandler: Code: 28. DB::Exception: Too high precision requested for Float, must not be more than 60, got 61: In scope SELECT toDecimalString(CAST('32.32', 'Float32'), 61). (CANNOT_PRINT_FLOAT_OR_DOUBLE_NUMBER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<_BitInt(8)>(int, FormatStringHelperImpl::type>, std::type_identity<_BitInt(8)>&&) @ 0x000000001aa332ea 4. void DB::(anonymous namespace)::FunctionToDecimalString::format(float, DB::WriteBuffer&, char8_t) @ 0x000000001aa31ec6 5. DB::(anonymous namespace)::FunctionToDecimalString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa104ae 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 2025.06.13 08:47:21.127639 [ 9257 ] {ef56a98f-0586-429f-ac52-16e9b7ccc0cd} executeQuery: Code: 28. DB::Exception: Too high precision requested for Float, must not be more than 60, got 61: In scope SELECT toDecimalString(CAST('64.64', 'Float64'), 61). (CANNOT_PRINT_FLOAT_OR_DOUBLE_NUMBER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36764) (comment: 02676_to_decimal_string.sql) (query 23, line 32) (in query: SELECT toDecimalString('64.64'::Float64, 61);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<_BitInt(8)>(int, FormatStringHelperImpl::type>, std::type_identity<_BitInt(8)>&&) @ 0x000000001aa332ea 4. void DB::(anonymous namespace)::FunctionToDecimalString::format(double, DB::WriteBuffer&, char8_t) @ 0x000000001aa3255a 5. DB::(anonymous namespace)::FunctionToDecimalString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa13a7c 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 2025.06.13 08:47:21.134022 [ 9257 ] {} TCPHandler: Code: 28. DB::Exception: Too high precision requested for Float, must not be more than 60, got 61: In scope SELECT toDecimalString(CAST('64.64', 'Float64'), 61). (CANNOT_PRINT_FLOAT_OR_DOUBLE_NUMBER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<_BitInt(8)>(int, FormatStringHelperImpl::type>, std::type_identity<_BitInt(8)>&&) @ 0x000000001aa332ea 4. void DB::(anonymous namespace)::FunctionToDecimalString::format(double, DB::WriteBuffer&, char8_t) @ 0x000000001aa3255a 5. DB::(anonymous namespace)::FunctionToDecimalString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa13a7c 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 2025.06.13 08:47:21.441409 [ 9257 ] {cc8672c5-83d4-40e6-a4c5-220ef1212dfd} executeQuery: Code: 28. DB::Exception: Too many fractional digits requested, shall not be more than 77: In scope SELECT toDecimalString(CAST('88', 'UInt8'), 78). (CANNOT_PRINT_FLOAT_OR_DOUBLE_NUMBER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36764) (comment: 02676_to_decimal_string.sql) (query 24, line 33) (in query: SELECT toDecimalString('88'::UInt8, 78);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000ac4b38a 4. DB::(anonymous namespace)::FunctionToDecimalString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa222c2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 08:47:21.444058 [ 9257 ] {} TCPHandler: Code: 28. DB::Exception: Too many fractional digits requested, shall not be more than 77: In scope SELECT toDecimalString(CAST('88', 'UInt8'), 78). (CANNOT_PRINT_FLOAT_OR_DOUBLE_NUMBER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000ac4b38a 4. DB::(anonymous namespace)::FunctionToDecimalString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa222c2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 08:47:21.728260 [ 9257 ] {7cc3370e-040c-4bbe-91f2-f1c3c53707ac} executeQuery: Code: 28. DB::Exception: Too many fractional digits requested, shall not be more than 77: In scope SELECT toDecimalString(CAST('646464', 'Int256'), 78). (CANNOT_PRINT_FLOAT_OR_DOUBLE_NUMBER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36764) (comment: 02676_to_decimal_string.sql) (query 25, line 34) (in query: SELECT toDecimalString('646464'::Int256, 78);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000ac4b38a 4. DB::(anonymous namespace)::FunctionToDecimalString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa21198 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 08:47:21.730902 [ 9257 ] {} TCPHandler: Code: 28. DB::Exception: Too many fractional digits requested, shall not be more than 77: In scope SELECT toDecimalString(CAST('646464', 'Int256'), 78). (CANNOT_PRINT_FLOAT_OR_DOUBLE_NUMBER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000ac4b38a 4. DB::(anonymous namespace)::FunctionToDecimalString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa21198 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 08:47:22.061254 [ 9257 ] {0960b06e-2a41-4193-9e41-063490e3a4a5} executeQuery: Code: 28. DB::Exception: Too many fractional digits requested for Decimal, must not be more than 77: In scope SELECT toDecimalString(CAST('-128.789323123321329854641231237893231233213298546', 'Decimal256(45)'), 78). (CANNOT_PRINT_FLOAT_OR_DOUBLE_NUMBER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36764) (comment: 02676_to_decimal_string.sql) (query 26, line 35) (in query: SELECT toDecimalString('-128.789323123321329854641231237893231233213298546'::Decimal256(45), 78);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000ac4b38a 4. DB::(anonymous namespace)::FunctionToDecimalString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa22592 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 08:47:22.065785 [ 9257 ] {} TCPHandler: Code: 28. DB::Exception: Too many fractional digits requested for Decimal, must not be more than 77: In scope SELECT toDecimalString(CAST('-128.789323123321329854641231237893231233213298546', 'Decimal256(45)'), 78). (CANNOT_PRINT_FLOAT_OR_DOUBLE_NUMBER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000ac4b38a 4. DB::(anonymous namespace)::FunctionToDecimalString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa22592 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 08:47:22.417696 [ 9257 ] {937d4caf-d63c-4f89-907a-2c84b7dc9782} executeQuery: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'precision' to function 'toDecimalString'. Expected: const Integer, got: UInt8: In scope SELECT toDecimalString(CAST('256.256', 'Decimal256(45)'), *). (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36764) (comment: 02676_to_decimal_string.sql) (query 27, line 37) (in query: -- wrong types: #52407 and similar SELECT toDecimalString('256.256'::Decimal256(45), *);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c037e87 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c0312c1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c02fb7f 6. DB::(anonymous namespace)::FunctionToDecimalString::getReturnTypeImpl(std::vector> const&) const @ 0x000000001aa2f2cd 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:47:22.420903 [ 9257 ] {} TCPHandler: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'precision' to function 'toDecimalString'. Expected: const Integer, got: UInt8: In scope SELECT toDecimalString(CAST('256.256', 'Decimal256(45)'), *). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c037e87 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c0312c1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c02fb7f 6. DB::(anonymous namespace)::FunctionToDecimalString::getReturnTypeImpl(std::vector> const&) const @ 0x000000001aa2f2cd 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:47:22.442313 [ 9257 ] {d7a09f41-9f0a-4fe6-87c3-3e8bb9e04240} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'precision' to function 'toDecimalString'. Expected: const Integer, got: String: In scope SELECT toDecimalString(CAST('128.128', 'Decimal128(30)'), 'str'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36764) (comment: 02676_to_decimal_string.sql) (query 28, line 39) (in query: SELECT toDecimalString('128.128'::Decimal128(30), 'str');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c037e87 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c0312c1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c02fb7f 6. DB::(anonymous namespace)::FunctionToDecimalString::getReturnTypeImpl(std::vector> const&) const @ 0x000000001aa2f2cd 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:47:22.445023 [ 9257 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'precision' to function 'toDecimalString'. Expected: const Integer, got: String: In scope SELECT toDecimalString(CAST('128.128', 'Decimal128(30)'), 'str'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c037e87 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c0312c1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c02fb7f 6. DB::(anonymous namespace)::FunctionToDecimalString::getReturnTypeImpl(std::vector> const&) const @ 0x000000001aa2f2cd 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:47:22.464379 [ 9257 ] {9ac67734-a5ae-4eb8-8c9d-64c6f2aeddc1} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimalString doesn't match: passed 1, should be 2: In scope SELECT toDecimalString(CAST('64.64', 'Decimal64(10)')). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36764) (comment: 02676_to_decimal_string.sql) (query 29, line 40) (in query: SELECT toDecimalString('64.64'::Decimal64(10));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:47:22.467512 [ 9257 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimalString doesn't match: passed 1, should be 2: In scope SELECT toDecimalString(CAST('64.64', 'Decimal64(10)')). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:47:22.489582 [ 9257 ] {6bf99d61-8740-4143-9d0b-047aa7bad8de} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimalString doesn't match: passed 3, should be 2: In scope SELECT toDecimalString(CAST('64.64', 'Decimal64(10)'), 3, 3). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36764) (comment: 02676_to_decimal_string.sql) (query 30, line 41) (in query: SELECT toDecimalString('64.64'::Decimal64(10), 3, 3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:47:22.492249 [ 9257 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimalString doesn't match: passed 3, should be 2: In scope SELECT toDecimalString(CAST('64.64', 'Decimal64(10)'), 3, 3). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:47:24.241132 [ 5281 ] {5a663f89-8d98-4b1d-818b-f8f6b1963958} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingAvg should be positive integer. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36896) (comment: 02817_group_array_moving_zero_window_size.sql) (query 1, line 1) (in query: SELECT groupArrayMovingAvg ( toInt64 ( 0 ) ) ( toDecimal32 ( 1 , 1 ) );), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:272: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000258f3ec6 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000203d4b63 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d009bfb 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303855f9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 08:47:24.244858 [ 5281 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingAvg should be positive integer. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:272: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000258f3ec6 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000203d4b63 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d009bfb 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303855f9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 08:47:26.609843 [ 2141 ] {} DynamicQueryHandler: Code: 115. DB::Exception: Setting input_format_with_names_use_headers is neither a builtin setting nor started with the prefix 'SQL_' or 'custom_' registered for user-defined settings: Maybe you meant ['input_format_with_names_use_header','input_format_with_types_use_header']. (UNKNOWN_SETTING), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Access/AccessControl.cpp:134: DB::AccessControl::CustomSettingsPrefixes::checkSettingNameIsAllowed(std::basic_string_view>) const @ 0x000000002e1ad6cb 5. ./build_docker/./src/Access/AccessControl.cpp:686: DB::AccessControl::checkSettingNameIsAllowed(std::basic_string_view>) const @ 0x000000002e1a9f06 6. ./build_docker/./src/Access/SettingsConstraints.cpp:279: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e5fb155 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e5fbbde 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000316f4b4e 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000316f5cb0 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc7f7b 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:47:28.566271 [ 9259 ] {3ca9aeec-4838-449b-bddd-a9a4cd8d8c80} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37068) (comment: 01602_max_distributed_connections.sh) (query 1, line 2) (in query: SELECT sleep(0.15) FROM remote('127.{1..10}', system.one) FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003adff16b 3. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003ade861b 4. ./build_docker/./src/Server/TCPHandler.cpp:1241: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe46c 5. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 08:47:28.568618 [ 9230 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:37740, local: [::ffff:127.0.0.6]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fbc2c6f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fbc3c01 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9b2eba 6. DB::ReadBuffer::next() @ 0x0000000008e83ccf 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003ad8c853 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:47:28.568926 [ 9230 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:37740, local: [::ffff:127.0.0.6]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fbc2c6f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fbc3c01 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9b2eba 6. DB::ReadBuffer::next() @ 0x0000000008e83ccf 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003ad8c853 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:47:28.607002 [ 9258 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:50670, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fbc2c6f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fbc3c01 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9b2eba 6. DB::ReadBuffer::next() @ 0x0000000008e83ccf 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003ad8c853 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:47:28.607288 [ 9258 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:50670, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fbc2c6f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fbc3c01 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9b2eba 6. DB::ReadBuffer::next() @ 0x0000000008e83ccf 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003ad8c853 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:47:28.612247 [ 2141 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:49214, local: [::ffff:127.0.0.1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fbc2c6f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fbc3c01 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9b2eba 6. DB::ReadBuffer::next() @ 0x0000000008e83ccf 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003ad8c853 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:47:28.613072 [ 2141 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:49214, local: [::ffff:127.0.0.1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fbc2c6f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fbc3c01 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9b2eba 6. DB::ReadBuffer::next() @ 0x0000000008e83ccf 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003ad8c853 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:47:28.615583 [ 9259 ] {3ca9aeec-4838-449b-bddd-a9a4cd8d8c80} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:37068). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2557: DB::TCPHandler::sendException(DB::Exception const&, bool) @ 0x000000003adb5f67 7. ./build_docker/./src/Server/TCPHandler.cpp:825: DB::TCPHandler::runImpl() @ 0x000000003ad8f542 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:47:28.622059 [ 2085 ] {13381ec8-bb44-4571-9e01-604260b21157} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:46100). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc8fc3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2569: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000003adc01f6 7. ./build_docker/./src/Server/TCPHandler.cpp:823: DB::TCPHandler::runImpl() @ 0x000000003ad8f4fc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:47:28.622237 [ 9259 ] {} TCPHandler: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003adff16b 3. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003ade861b 4. ./build_docker/./src/Server/TCPHandler.cpp:1241: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe46c 5. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 08:47:28.640981 [ 9240 ] {60a9709e-f750-46b4-9bf1-dd4e917937f7} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.5]:9000 -> [::ffff:127.0.0.1]:55736). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc8fc3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2569: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000003adc01f6 7. ./build_docker/./src/Server/TCPHandler.cpp:823: DB::TCPHandler::runImpl() @ 0x000000003ad8f4fc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:47:28.642630 [ 9260 ] {1304dc6a-2b57-4f11-ad9e-ae8212264e83} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.4]:9000 -> [::ffff:127.0.0.1]:49184). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc8fc3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2569: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000003adc01f6 7. ./build_docker/./src/Server/TCPHandler.cpp:823: DB::TCPHandler::runImpl() @ 0x000000003ad8f4fc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:47:28.949847 [ 3255 ] {bbc94360-4354-4c1e-9ffc-5411dd7201d4} executeQuery: Code: 53. DB::Exception: Cannot convert string 'qEkek..' to type IntervalMinute. (TYPE_MISMATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37096) (comment: 01277_convert_field_to_type_logical_error.sql) (query 1, line 1) (in query: SELECT -2487, globalNullIn(toIntervalMinute(-88074), 'qEkek..'), [-27.537293];), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000003368310c 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000003367a53e 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x00000000336840f0 7. ./build_docker/./src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x000000003105eb0c 8. ./build_docker/./src/Analyzer/SetUtils.cpp:99: std::vector> DB::(anonymous namespace)::createBlockFromCollection(DB::Array const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, DB::GetSetElementParams) @ 0x000000003105bf84 9. ./build_docker/./src/Analyzer/SetUtils.cpp:184: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x00000000310573b7 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3511: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303847dc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:47:28.952890 [ 3255 ] {} TCPHandler: Code: 53. DB::Exception: Cannot convert string 'qEkek..' to type IntervalMinute. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000003368310c 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000003367a53e 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x00000000336840f0 7. ./build_docker/./src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x000000003105eb0c 8. ./build_docker/./src/Analyzer/SetUtils.cpp:99: std::vector> DB::(anonymous namespace)::createBlockFromCollection(DB::Array const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, DB::GetSetElementParams) @ 0x000000003105bf84 9. ./build_docker/./src/Analyzer/SetUtils.cpp:184: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x00000000310573b7 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3511: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303847dc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:47:29.677668 [ 9260 ] {055d2f5f-f6ce-4aa6-b632-7fb02e8a06f8} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37112) (comment: 01602_max_distributed_connections.sh) (query 1, line 2) (in query: SELECT sleep(0.15) FROM remote('127.{1..10}', system.one) FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003adff16b 3. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003ade861b 4. ./build_docker/./src/Server/TCPHandler.cpp:1241: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe46c 5. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 08:47:29.690910 [ 2134 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:46102, local: [::ffff:127.0.0.3]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fbc2c6f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fbc3c01 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9b2eba 6. DB::ReadBuffer::next() @ 0x0000000008e83ccf 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003ad8c853 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:47:29.691400 [ 2134 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:46102, local: [::ffff:127.0.0.3]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fbc2c6f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fbc3c01 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9b2eba 6. DB::ReadBuffer::next() @ 0x0000000008e83ccf 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003ad8c853 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:47:29.703007 [ 9260 ] {055d2f5f-f6ce-4aa6-b632-7fb02e8a06f8} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:37112). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2557: DB::TCPHandler::sendException(DB::Exception const&, bool) @ 0x000000003adb5f67 7. ./build_docker/./src/Server/TCPHandler.cpp:825: DB::TCPHandler::runImpl() @ 0x000000003ad8f542 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:47:29.712547 [ 9260 ] {} TCPHandler: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003adff16b 3. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003ade861b 4. ./build_docker/./src/Server/TCPHandler.cpp:1241: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe46c 5. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 08:47:29.772085 [ 9258 ] {2de5bdd2-fdeb-4674-97a0-ee2c8321e5e4} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.4]:9000 -> [::ffff:127.0.0.1]:49190). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc8fc3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2569: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000003adc01f6 7. ./build_docker/./src/Server/TCPHandler.cpp:823: DB::TCPHandler::runImpl() @ 0x000000003ad8f4fc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:47:29.803475 [ 9240 ] {c5c053b4-4183-42ab-9247-b49b3fc21d78} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.7]:9000 -> [::ffff:127.0.0.1]:38408). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc8fc3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2569: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000003adc01f6 7. ./build_docker/./src/Server/TCPHandler.cpp:823: DB::TCPHandler::runImpl() @ 0x000000003ad8f4fc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:47:29.806596 [ 9230 ] {5d9ebbe3-1f53-4dd1-b8b1-30c22044e4a1} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.8]:9000 -> [::ffff:127.0.0.1]:58670). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc8fc3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2569: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000003adc01f6 7. ./build_docker/./src/Server/TCPHandler.cpp:823: DB::TCPHandler::runImpl() @ 0x000000003ad8f4fc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:47:29.819877 [ 2142 ] {4d3ba1f8-0f38-443c-a571-d88acf659723} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.5]:9000 -> [::ffff:127.0.0.1]:55746). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc8fc3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2569: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000003adc01f6 7. ./build_docker/./src/Server/TCPHandler.cpp:823: DB::TCPHandler::runImpl() @ 0x000000003ad8f4fc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:47:29.834287 [ 2085 ] {271852cd-5e04-4a1c-84ae-5bc089a60a9b} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.6]:9000 -> [::ffff:127.0.0.1]:37746). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc8fc3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2569: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000003adc01f6 7. ./build_docker/./src/Server/TCPHandler.cpp:823: DB::TCPHandler::runImpl() @ 0x000000003ad8f4fc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:47:29.836343 [ 9228 ] {680ff31b-794c-482e-af4b-317b5269f006} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.9]:9000 -> [::ffff:127.0.0.1]:58802). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc8fc3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2569: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000003adc01f6 7. ./build_docker/./src/Server/TCPHandler.cpp:823: DB::TCPHandler::runImpl() @ 0x000000003ad8f4fc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:47:29.850153 [ 3514 ] {bfa787d0-1c7f-41c8-8a7f-9e18a0b2dd7a} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.10]:9000 -> [::ffff:127.0.0.1]:48584). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2569: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000003adc01f6 7. ./build_docker/./src/Server/TCPHandler.cpp:823: DB::TCPHandler::runImpl() @ 0x000000003ad8f4fc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:47:31.797206 [ 2085 ] {c34ba9dd-4ad5-49d1-bcd2-c12bb04bface} executeQuery: Code: 43. DB::Exception: Provided time zone must be non-empty: while executing 'FUNCTION formatDateTime(_CAST(1692977400_Nullable(DateTime('UTC')), 'Nullable(DateTime('UTC'))'_String) :: 1, '%H%i%S'_String :: 2, toString(if(modulo(__table1.number, 2_UInt8), _CAST(''_String, 'Enum8(\'\' = 1, \'Europe/Amsterdam\' = 2)'_String), _CAST('Europe/Amsterdam'_String, 'Enum8(\'\' = 1, \'Europe/Amsterdam\' = 2)'_String))) :: 5) -> formatDateTime(_CAST(1692977400_Nullable(DateTime('UTC')), 'Nullable(DateTime('UTC'))'_String), '%H%i%S'_String, toString(if(modulo(__table1.number, 2_UInt8), _CAST(''_String, 'Enum8(\'\' = 1, \'Europe/Amsterdam\' = 2)'_String), _CAST('Europe/Amsterdam'_String, 'Enum8(\'\' = 1, \'Europe/Amsterdam\' = 2)'_String)))) Nullable(String) : 3'. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37200) (comment: 02863_non_const_timezone_check.sql) (query 6, line 11) (in query: SELECT formatDateTime((SELECT materialize(date) FROM Dates), '%H%i%S', number % 2 ? '' : 'Europe/Amsterdam') FROM numbers(5);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ec1a01b 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::defaultImplementationForNulls(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfedc88 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb51f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 2025.06.13 08:47:31.802063 [ 2085 ] {} TCPHandler: Code: 43. DB::Exception: Provided time zone must be non-empty: while executing 'FUNCTION formatDateTime(_CAST(1692977400_Nullable(DateTime('UTC')), 'Nullable(DateTime('UTC'))'_String) :: 1, '%H%i%S'_String :: 2, toString(if(modulo(__table1.number, 2_UInt8), _CAST(''_String, 'Enum8(\'\' = 1, \'Europe/Amsterdam\' = 2)'_String), _CAST('Europe/Amsterdam'_String, 'Enum8(\'\' = 1, \'Europe/Amsterdam\' = 2)'_String))) :: 5) -> formatDateTime(_CAST(1692977400_Nullable(DateTime('UTC')), 'Nullable(DateTime('UTC'))'_String), '%H%i%S'_String, toString(if(modulo(__table1.number, 2_UInt8), _CAST(''_String, 'Enum8(\'\' = 1, \'Europe/Amsterdam\' = 2)'_String), _CAST('Europe/Amsterdam'_String, 'Enum8(\'\' = 1, \'Europe/Amsterdam\' = 2)'_String)))) Nullable(String) : 3'. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ec1a01b 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::defaultImplementationForNulls(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfedc88 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb51f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:47:31.904375 [ 9258 ] {7e7512eb-1349-4648-bc78-9c3a42349c20} executeQuery: Code: 48. DB::Exception: MergeJoinAlgorithm does not implement ASOF Right join. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37184) (comment: 03149_asof_join_ddb_timestamps.sql) (query 15, line 66) (in query: SELECT p.begin, e.value FROM probe0 p ASOF RIGHT JOIN events0 e ON p.begin >= e.begin ORDER BY e.begin ASC;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::JoinKind&) @ 0x000000003ba73f6a 4. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:451: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(DB::JoinKind, DB::JoinStrictness, DB::TableJoin::JoinOnClause const&, std::vector> const&, unsigned long) @ 0x000000003ba550f5 5. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:470: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(std::shared_ptr, std::vector> const&, unsigned long) @ 0x000000003ba55db1 6. ./src/Processors/Merges/IMergingTransform.h:112: DB::MergeJoinTransform::MergeJoinTransform(std::shared_ptr, std::vector> const&, DB::Block const&, unsigned long, unsigned long) @ 0x000000003ba71ff0 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&, 0>(std::allocator const&, std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&) @ 0x000000002f1ab9f5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::QueryPipelineBuilder::joinPipelinesYShaped(std::unique_ptr>, std::unique_ptr>, std::shared_ptr, DB::Block const&, unsigned long, std::vector, std::allocator>>*) @ 0x000000002f19182e 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:114: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c073ca6 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 2025.06.13 08:47:31.908873 [ 9258 ] {} TCPHandler: Code: 48. DB::Exception: MergeJoinAlgorithm does not implement ASOF Right join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::JoinKind&) @ 0x000000003ba73f6a 4. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:451: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(DB::JoinKind, DB::JoinStrictness, DB::TableJoin::JoinOnClause const&, std::vector> const&, unsigned long) @ 0x000000003ba550f5 5. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:470: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(std::shared_ptr, std::vector> const&, unsigned long) @ 0x000000003ba55db1 6. ./src/Processors/Merges/IMergingTransform.h:112: DB::MergeJoinTransform::MergeJoinTransform(std::shared_ptr, std::vector> const&, DB::Block const&, unsigned long, unsigned long) @ 0x000000003ba71ff0 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&, 0>(std::allocator const&, std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&) @ 0x000000002f1ab9f5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::QueryPipelineBuilder::joinPipelinesYShaped(std::unique_ptr>, std::unique_ptr>, std::shared_ptr, DB::Block const&, unsigned long, std::vector, std::allocator>>*) @ 0x000000002f19182e 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:114: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c073ca6 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 2025.06.13 08:47:32.138075 [ 9258 ] {4afa6af2-6b30-43e8-897c-9a329854a36b} executeQuery: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37184) (comment: 03149_asof_join_ddb_timestamps.sql) (query 16, line 74) (in query: SELECT p.begin, e.value FROM probe0 p ASOF RIGHT JOIN events0 e USING (begin) ORDER BY e.begin ASC;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1283: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x0000000032bf4153 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003c09e07a 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x000000003c3e710a 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c3be655 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f95f8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:47:32.141802 [ 9258 ] {} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1283: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x0000000032bf4153 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003c09e07a 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x000000003c3e710a 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c3be655 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f95f8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:47:32.337012 [ 2085 ] {37b7eb25-1856-4bcf-a800-ab9c5e7d75da} executeQuery: Code: 43. DB::Exception: Provided time zone must be non-empty: while executing 'FUNCTION toString(_CAST(1692977400_Nullable(DateTime('UTC')), 'Nullable(DateTime('UTC'))'_String) :: 1, toString(if(modulo(__table1.number, 2_UInt8), _CAST('America/Los_Angeles'_String, 'Enum8(\'\' = 1, \'America/Los_Angeles\' = 2)'_String), _CAST(''_String, 'Enum8(\'\' = 1, \'America/Los_Angeles\' = 2)'_String))) :: 4) -> toString(_CAST(1692977400_Nullable(DateTime('UTC')), 'Nullable(DateTime('UTC'))'_String), toString(if(modulo(__table1.number, 2_UInt8), _CAST('America/Los_Angeles'_String, 'Enum8(\'\' = 1, \'America/Los_Angeles\' = 2)'_String), _CAST(''_String, 'Enum8(\'\' = 1, \'America/Los_Angeles\' = 2)'_String)))) Nullable(String) : 2'. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37200) (comment: 02863_non_const_timezone_check.sql) (query 9, line 17) (in query: SELECT toString((SELECT materialize(date) FROM Dates), number % 2 ? 'America/Los_Angeles' : '') FROM numbers(5);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./src/Functions/FunctionsConversion.h:1408: COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ccb8d42 5. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cc901f9 6. ./src/Core/callOnTypeIndex.h:277: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c84e0bb 7. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c84c842 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:47:32.342954 [ 2085 ] {} TCPHandler: Code: 43. DB::Exception: Provided time zone must be non-empty: while executing 'FUNCTION toString(_CAST(1692977400_Nullable(DateTime('UTC')), 'Nullable(DateTime('UTC'))'_String) :: 1, toString(if(modulo(__table1.number, 2_UInt8), _CAST('America/Los_Angeles'_String, 'Enum8(\'\' = 1, \'America/Los_Angeles\' = 2)'_String), _CAST(''_String, 'Enum8(\'\' = 1, \'America/Los_Angeles\' = 2)'_String))) :: 4) -> toString(_CAST(1692977400_Nullable(DateTime('UTC')), 'Nullable(DateTime('UTC'))'_String), toString(if(modulo(__table1.number, 2_UInt8), _CAST('America/Los_Angeles'_String, 'Enum8(\'\' = 1, \'America/Los_Angeles\' = 2)'_String), _CAST(''_String, 'Enum8(\'\' = 1, \'America/Los_Angeles\' = 2)'_String)))) Nullable(String) : 2'. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./src/Functions/FunctionsConversion.h:1408: COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ccb8d42 5. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cc901f9 6. ./src/Core/callOnTypeIndex.h:277: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c84e0bb 7. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c84c842 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:47:34.702892 [ 3514 ] {854f40c2-afbf-4ff1-9d88-007db5e02035} executeQuery: Code: 43. DB::Exception: Invalid origin H3 index: 37480377652084735: In scope SELECT h3GetUnidirectionalEdge(stringToH3('85283473ffffff'), stringToH3('852\03477fffffff')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47006) (comment: 02292_h3_unidirectional_funcs.sql) (query 19, line 26) (in query: SELECT h3GetUnidirectionalEdge(stringToH3('85283473ffffff'), stringToH3('852\03477fffffff'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000ac4b38a 4. DB::(anonymous namespace)::FunctionH3GetUnidirectionalEdge::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001151ddbc 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 08:47:34.705747 [ 3514 ] {} TCPHandler: Code: 43. DB::Exception: Invalid origin H3 index: 37480377652084735: In scope SELECT h3GetUnidirectionalEdge(stringToH3('85283473ffffff'), stringToH3('852\03477fffffff')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000ac4b38a 4. DB::(anonymous namespace)::FunctionH3GetUnidirectionalEdge::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001151ddbc 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 08:47:34.868909 [ 488 ] {} test_yswjsvt0.r2 (c6d6b4f7-5981-4cca-b9a4-d91c60646816): Will mimic 1r1 2025.06.13 08:47:37.958001 [ 9234 ] {f5f4f690-6687-42fc-bccd-7c193a29188d} executeQuery: Code: 36. DB::Exception: Function icebergTruncate accepts only positive width: In scope SELECT icebergTruncate(0, 55). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47280) (comment: 03376_iceberg_truncate.sql) (query 37, line 45) (in query: SELECT icebergTruncate(0, 55);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::(anonymous namespace)::FunctionIcebergTruncate::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000115d292f 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 08:47:37.961476 [ 9234 ] {} TCPHandler: Code: 36. DB::Exception: Function icebergTruncate accepts only positive width: In scope SELECT icebergTruncate(0, 55). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::(anonymous namespace)::FunctionIcebergTruncate::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000115d292f 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 08:47:38.277490 [ 9234 ] {1791fc40-a6ab-4724-9a6a-d9915c2d5fed} executeQuery: Code: 43. DB::Exception: First argument should be UInt data type: In scope SELECT icebergTruncate(-1, 55). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47280) (comment: 03376_iceberg_truncate.sql) (query 38, line 46) (in query: SELECT icebergTruncate(-1, 55);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::(anonymous namespace)::FunctionIcebergTruncate::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000115d6db1 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:47:38.280381 [ 9234 ] {} TCPHandler: Code: 43. DB::Exception: First argument should be UInt data type: In scope SELECT icebergTruncate(-1, 55). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::(anonymous namespace)::FunctionIcebergTruncate::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000115d6db1 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:47:38.623497 [ 9234 ] {838eddea-4e24-4cc4-baf2-033f09ef21ed} executeQuery: Code: 43. DB::Exception: Second argument must be of native integer type, String/FixedString, Decimal: In scope SELECT icebergTruncate(3, 0.). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47280) (comment: 03376_iceberg_truncate.sql) (query 39, line 47) (in query: SELECT icebergTruncate(3, 0.0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::(anonymous namespace)::FunctionIcebergTruncate::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000115d7311 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:47:38.626839 [ 9234 ] {} TCPHandler: Code: 43. DB::Exception: Second argument must be of native integer type, String/FixedString, Decimal: In scope SELECT icebergTruncate(3, 0.). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::(anonymous namespace)::FunctionIcebergTruncate::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000115d7311 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:47:40.041785 [ 4330 ] {b795b09b-b908-4929-acbf-2c6454a44acf} executeQuery: Code: 407. DB::Exception: DateTime64 convert overflow. Float is out of Decimal range: In scope SELECT toDateTime64(9300000000., 9, 'UTC'). (DECIMAL_OVERFLOW) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47614) (comment: 01734_datetime64_from_float.sql) (query 14, line 20) (in query: SELECT toDateTime64(9300000000.0, 9, 'UTC');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c2574a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDateTime64, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f3ab5ee 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDateTime64>(T::FieldType const&, unsigned int) @ 0x000000002f3b01f5 6. COW::immutable_ptr DB::DateTimeTransformImpl, DB::DataTypeDateTime64, DB::detail::ToDateTime64TransformFloat, double, (DB::FormatSettings::DateTimeOverflowBehavior)0>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::ToDateTime64TransformFloat, double, (DB::FormatSettings::DateTimeOverflowBehavior)0> const&) @ 0x000000002c72c53f 7. ./src/Functions/FunctionsConversion.h:1298: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDateTime64>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cbe646d 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c7f10c3 9. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c83f477 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c83e462 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 2025.06.13 08:47:40.045340 [ 4330 ] {} TCPHandler: Code: 407. DB::Exception: DateTime64 convert overflow. Float is out of Decimal range: In scope SELECT toDateTime64(9300000000., 9, 'UTC'). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c2574a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDateTime64, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f3ab5ee 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDateTime64>(T::FieldType const&, unsigned int) @ 0x000000002f3b01f5 6. COW::immutable_ptr DB::DateTimeTransformImpl, DB::DataTypeDateTime64, DB::detail::ToDateTime64TransformFloat, double, (DB::FormatSettings::DateTimeOverflowBehavior)0>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::ToDateTime64TransformFloat, double, (DB::FormatSettings::DateTimeOverflowBehavior)0> const&) @ 0x000000002c72c53f 7. ./src/Functions/FunctionsConversion.h:1298: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDateTime64>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cbe646d 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c7f10c3 9. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c83f477 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c83e462 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 2025.06.13 08:47:40.431109 [ 4330 ] {dddfd695-7dea-486c-9b6b-fd15622b9bb5} executeQuery: Code: 407. DB::Exception: Decimal math overflow: In scope SELECT toDateTime64(9300000000, 9, 'UTC'). (DECIMAL_OVERFLOW) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47614) (comment: 01734_datetime64_from_float.sql) (query 15, line 21) (in query: SELECT toDateTime64(9300000000, 9, 'UTC');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. bool DB::DecimalUtils::multiplyAdd(long const&, long const&, long const&, long&) @ 0x0000000008e1d524 5. COW::immutable_ptr DB::DateTimeTransformImpl, DB::DataTypeDateTime64, DB::detail::ToDateTime64TransformUnsigned, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::ToDateTime64TransformUnsigned const&) @ 0x000000002c722e69 6. ./src/Functions/FunctionsConversion.h:1290: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDateTime64>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cbdc889 7. ./src/Core/callOnTypeIndex.h:255: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c7f11a3 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c83f477 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c83e462 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 2025.06.13 08:47:40.434192 [ 4330 ] {} TCPHandler: Code: 407. DB::Exception: Decimal math overflow: In scope SELECT toDateTime64(9300000000, 9, 'UTC'). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. bool DB::DecimalUtils::multiplyAdd(long const&, long const&, long const&, long&) @ 0x0000000008e1d524 5. COW::immutable_ptr DB::DateTimeTransformImpl, DB::DataTypeDateTime64, DB::detail::ToDateTime64TransformUnsigned, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::ToDateTime64TransformUnsigned const&) @ 0x000000002c722e69 6. ./src/Functions/FunctionsConversion.h:1290: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDateTime64>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cbdc889 7. ./src/Core/callOnTypeIndex.h:255: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c7f11a3 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c83f477 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c83e462 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 2025.06.13 08:47:43.451846 [ 2142 ] {151807fe-26e2-4d24-bf38-7de95a6f21a3} executeQuery: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT accurateCastOrNull(JSON_VALUE('', ''), 'String'). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47010) (comment: 02366_kql_func_string.sql) (query 165, line 190) (in query: print extract_json('', '');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, bool) @ 0x0000000008c131b1 5. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c1156c 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:47:43.455254 [ 2142 ] {} TCPHandler: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT accurateCastOrNull(JSON_VALUE('', ''), 'String'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, bool) @ 0x0000000008c131b1 5. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c1156c 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:47:43.476051 [ 2142 ] {4fae5a20-1f2a-4a40-9aa2-c136c8703919} executeQuery: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT accurateCastOrNull(JSON_VALUE('', 'a'), 'String'). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47010) (comment: 02366_kql_func_string.sql) (query 166, line 191) (in query: print extract_json('a', '');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, bool) @ 0x0000000008c131b1 5. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c1156c 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:47:43.482936 [ 2142 ] {} TCPHandler: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT accurateCastOrNull(JSON_VALUE('', 'a'), 'String'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, bool) @ 0x0000000008c131b1 5. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c1156c 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:47:46.095633 [ 2142 ] {dfd61dfb-6311-488b-ab2d-fb9dcbabef16} executeQuery: Code: 395. DB::Exception: Expected guid as argument: while executing 'FUNCTION if(_CAST(1_UInt8, 'UInt8'_String) :: 1, toString(throwIf(1_Bool, 'Expected guid as argument'_String)) :: 3, _CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String) :: 4) -> if(_CAST(1_UInt8, 'UInt8'_String), toString(throwIf(1_Bool, 'Expected guid as argument'_String)), _CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String)) Nullable(String) : 5'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47010) (comment: 02366_kql_func_string.sql) (query 197, line 226) (in query: print base64_encode_fromguid(dynamic(null));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::createRuntime(int, String const&) @ 0x000000001a9917fa 3. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98b903 4. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 8. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff69df 9. ./build_docker/./src/Columns/ColumnFunction.cpp:372: DB::ColumnFunction::reduce() const @ 0x0000000037416960 10. ./build_docker/./src/Columns/ColumnFunction.cpp:361: DB::ColumnFunction::reduce() const @ 0x00000000374161dd 11. ./build_docker/./src/Columns/MaskOperations.cpp:299: DB::executeColumnIfNeeded(DB::ColumnWithTypeAndName&, bool) @ 0x000000003814108d 12. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000305b7c90 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:47:46.102469 [ 2142 ] {} TCPHandler: Code: 395. DB::Exception: Expected guid as argument: while executing 'FUNCTION if(_CAST(1_UInt8, 'UInt8'_String) :: 1, toString(throwIf(1_Bool, 'Expected guid as argument'_String)) :: 3, _CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String) :: 4) -> if(_CAST(1_UInt8, 'UInt8'_String), toString(throwIf(1_Bool, 'Expected guid as argument'_String)), _CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String)) Nullable(String) : 5'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::createRuntime(int, String const&) @ 0x000000001a9917fa 3. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98b903 4. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 8. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff69df 9. ./build_docker/./src/Columns/ColumnFunction.cpp:372: DB::ColumnFunction::reduce() const @ 0x0000000037416960 10. ./build_docker/./src/Columns/ColumnFunction.cpp:361: DB::ColumnFunction::reduce() const @ 0x00000000374161dd 11. ./build_docker/./src/Columns/MaskOperations.cpp:299: DB::executeColumnIfNeeded(DB::ColumnWithTypeAndName&, bool) @ 0x000000003814108d 12. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000305b7c90 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:47:46.272354 [ 2142 ] {65c30301-5ce2-4cfe-86bb-5f3717d894d2} executeQuery: Code: 395. DB::Exception: Expected guid as argument: while executing 'FUNCTION throwIf(1_Bool :: 1, 'Expected guid as argument'_String :: 2) -> throwIf(1_Bool, 'Expected guid as argument'_String) UInt8 : 3'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47010) (comment: 02366_kql_func_string.sql) (query 198, line 227) (in query: print base64_encode_fromguid("abcd1231");), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::createRuntime(int, String const&) @ 0x000000001a9917fa 3. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98b903 4. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 8. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 9. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 10. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 11. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:47:46.279103 [ 2142 ] {} TCPHandler: Code: 395. DB::Exception: Expected guid as argument: while executing 'FUNCTION throwIf(1_Bool :: 1, 'Expected guid as argument'_String :: 2) -> throwIf(1_Bool, 'Expected guid as argument'_String) UInt8 : 3'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::createRuntime(int, String const&) @ 0x000000001a9917fa 3. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98b903 4. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 8. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 9. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 10. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 11. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:47:49.596425 [ 2142 ] {1fec03be-c55f-42dd-9232-8eeb38f01192} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 's' to function 'splitByChar'. Expected: String, got: UInt8: In scope SELECT if((length(splitByChar('.', 42)) > 4) OR (length(splitByChar('.', 42)) < 1) OR (match(42, '.*[a-zA-Z]+.*') = 1), toDecimal128OrNull('NULL', 0), toDecimal128OrNull(substring(arrayStringConcat(arrayMap(x -> leftPad(x, 8, '0'), arrayMap(x -> if(empty(x), '0', x), arrayResize(splitByChar('.', 42), 4)))), 8), 0)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47010) (comment: 02366_kql_func_string.sql) (query 246, line 275) (in query: print parse_version(42);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c037e87 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c0312c1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c02fb7f 6. DB::FunctionTokens::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a5478ee 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030374611 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 2025.06.13 08:47:49.610556 [ 2142 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 's' to function 'splitByChar'. Expected: String, got: UInt8: In scope SELECT if((length(splitByChar('.', 42)) > 4) OR (length(splitByChar('.', 42)) < 1) OR (match(42, '.*[a-zA-Z]+.*') = 1), toDecimal128OrNull('NULL', 0), toDecimal128OrNull(substring(arrayStringConcat(arrayMap(x -> leftPad(x, 8, '0'), arrayMap(x -> if(empty(x), '0', x), arrayResize(splitByChar('.', 42), 4)))), 8), 0)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c037e87 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c0312c1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c02fb7f 6. DB::FunctionTokens::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a5478ee 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030374611 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 2025.06.13 08:47:51.295655 [ 2142 ] {eb61a376-91f4-4323-8e7a-0e65103a81d0} executeQuery: Code: 43. DB::Exception: Illegal type UInt8 of argument of function empty: In scope SELECT if(empty(55) OR hasAll(splitByChar(' ', 55), ['']), arrayMap(x -> NULL, splitByChar(' ', '')), splitByChar(' ', 55)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47010) (comment: 02366_kql_func_string.sql) (query 259, line 289) (in query: print parse_command_line(55, 'windows');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::(anonymous namespace)::FunctionEmptyOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000dd95e3b 5. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a174126 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030374611 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 2025.06.13 08:47:51.299037 [ 2142 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type UInt8 of argument of function empty: In scope SELECT if(empty(55) OR hasAll(splitByChar(' ', 55), ['']), arrayMap(x -> NULL, splitByChar(' ', '')), splitByChar(' ', 55)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::(anonymous namespace)::FunctionEmptyOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000dd95e3b 5. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a174126 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030374611 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 2025.06.13 08:47:52.638769 [ 2142 ] {3cc068a7-f1fa-4125-b678-85c247bbc7d9} executeQuery: Code: 43. DB::Exception: Illegal type UInt8 of argument of function position: In scope SELECT if(CAST(position(65, '\n'), 'UInt8'), splitByChar(',', substring(65, 1, position(65, '\n') - 1)), splitByChar(',', substring(65, 1, length(65)))). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47010) (comment: 02366_kql_func_string.sql) (query 274, line 309) (in query: print parse_csv(65);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019fbb1c1 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030374611 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 2025.06.13 08:47:52.641993 [ 2142 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type UInt8 of argument of function position: In scope SELECT if(CAST(position(65, '\n'), 'UInt8'), splitByChar(',', substring(65, 1, position(65, '\n') - 1)), splitByChar(',', substring(65, 1, length(65)))). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019fbb1c1 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030374611 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 2025.06.13 08:47:57.111752 [ 4743 ] {45afef99-3588-49a9-9731-df8c08a335d0} BackupsWorker: Failed to make backup Disk('backups', 'test_s3_backup'): Code: 598. DB::Exception: Backup Disk('backups', 'test_s3_backup') already exists. (BACKUP_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Backups/BackupImpl.cpp:533: DB::BackupImpl::checkBackupDoesntExist() const @ 0x000000002e7c51c2 5. ./build_docker/./src/Backups/BackupImpl.cpp:177: DB::BackupImpl::open() @ 0x000000002e7c1379 6. ./build_docker/./src/Backups/BackupImpl.cpp:133: DB::BackupImpl::BackupImpl(DB::BackupFactory::CreateParams, DB::BackupImpl::ArchiveParams const&, std::shared_ptr) @ 0x000000002e7c2b6e 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::registerBackupEnginesFileAndDisk(DB::BackupFactory&)::$_0::operator()(DB::BackupFactory::CreateParams const&) const @ 0x000000002ea04b13 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl[abi:ne190107] (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000002e9ff875 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002e7a3624 10. ./build_docker/./src/Backups/BackupsWorker.cpp:531: DB::BackupsWorker::openBackupForWriting(DB::BackupInfo const&, DB::BackupSettings const&, std::shared_ptr, std::shared_ptr const&) const @ 0x000000002e7641b1 11. ./build_docker/./src/Backups/BackupsWorker.cpp:416: DB::BackupsWorker::BackupStarter::doBackup() @ 0x000000002e792c3c 12. ./build_docker/./src/Backups/BackupsWorker.cpp:488: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002e78495e 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d800601 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::__packaged_task_func (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority)::'lambda'(), std::allocator (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority)::'lambda'()>, void ()>::operator()() @ 0x000000002d80044d 15. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002d800cdd 16. ./src/Common/threadPoolCallbackRunner.h:52: void std::__function::__policy_invoker::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority)::'lambda0'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d800b4e 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d7fe781 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d7fe1a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002e760c76 7. ./build_docker/./src/Backups/BackupsWorker.cpp:334: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e760348 8. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x00000000338e9989 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:47:57.128987 [ 9263 ] {45afef99-3588-49a9-9731-df8c08a335d0} executeQuery: Code: 598. DB::Exception: Backup Disk('backups', 'test_s3_backup') already exists. (BACKUP_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44932) (comment: 02731_zero_objects_in_metadata.sh) (query 1, line 2) (in query: BACKUP TABLE test TO Disk('backups', 'test_s3_backup');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Backups/BackupImpl.cpp:533: DB::BackupImpl::checkBackupDoesntExist() const @ 0x000000002e7c51c2 5. ./build_docker/./src/Backups/BackupImpl.cpp:177: DB::BackupImpl::open() @ 0x000000002e7c1379 6. ./build_docker/./src/Backups/BackupImpl.cpp:133: DB::BackupImpl::BackupImpl(DB::BackupFactory::CreateParams, DB::BackupImpl::ArchiveParams const&, std::shared_ptr) @ 0x000000002e7c2b6e 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::registerBackupEnginesFileAndDisk(DB::BackupFactory&)::$_0::operator()(DB::BackupFactory::CreateParams const&) const @ 0x000000002ea04b13 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl[abi:ne190107] (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000002e9ff875 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002e7a3624 10. ./build_docker/./src/Backups/BackupsWorker.cpp:531: DB::BackupsWorker::openBackupForWriting(DB::BackupInfo const&, DB::BackupSettings const&, std::shared_ptr, std::shared_ptr const&) const @ 0x000000002e7641b1 11. ./build_docker/./src/Backups/BackupsWorker.cpp:416: DB::BackupsWorker::BackupStarter::doBackup() @ 0x000000002e792c3c 12. ./build_docker/./src/Backups/BackupsWorker.cpp:488: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002e78495e 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d800601 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::__packaged_task_func (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority)::'lambda'(), std::allocator (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority)::'lambda'()>, void ()>::operator()() @ 0x000000002d80044d 15. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002d800cdd 16. ./src/Common/threadPoolCallbackRunner.h:52: void std::__function::__policy_invoker::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority)::'lambda0'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d800b4e 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 2025.06.13 08:47:57.142545 [ 9263 ] {} TCPHandler: Code: 598. DB::Exception: Backup Disk('backups', 'test_s3_backup') already exists. (BACKUP_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Backups/BackupImpl.cpp:533: DB::BackupImpl::checkBackupDoesntExist() const @ 0x000000002e7c51c2 5. ./build_docker/./src/Backups/BackupImpl.cpp:177: DB::BackupImpl::open() @ 0x000000002e7c1379 6. ./build_docker/./src/Backups/BackupImpl.cpp:133: DB::BackupImpl::BackupImpl(DB::BackupFactory::CreateParams, DB::BackupImpl::ArchiveParams const&, std::shared_ptr) @ 0x000000002e7c2b6e 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::registerBackupEnginesFileAndDisk(DB::BackupFactory&)::$_0::operator()(DB::BackupFactory::CreateParams const&) const @ 0x000000002ea04b13 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl[abi:ne190107] (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000002e9ff875 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002e7a3624 10. ./build_docker/./src/Backups/BackupsWorker.cpp:531: DB::BackupsWorker::openBackupForWriting(DB::BackupInfo const&, DB::BackupSettings const&, std::shared_ptr, std::shared_ptr const&) const @ 0x000000002e7641b1 11. ./build_docker/./src/Backups/BackupsWorker.cpp:416: DB::BackupsWorker::BackupStarter::doBackup() @ 0x000000002e792c3c 12. ./build_docker/./src/Backups/BackupsWorker.cpp:488: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002e78495e 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d800601 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::__packaged_task_func (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority)::'lambda'(), std::allocator (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority)::'lambda'()>, void ()>::operator()() @ 0x000000002d80044d 15. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002d800cdd 16. ./src/Common/threadPoolCallbackRunner.h:52: void std::__function::__policy_invoker::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority)::'lambda0'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d800b4e 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d7fe781 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d7fe1a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002e760c76 7. ./build_docker/./src/Backups/BackupsWorker.cpp:334: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e760348 8. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x00000000338e9989 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:47:57.865660 [ 9220 ] {003ca45c-099d-481e-b92f-f595e25b9ae3} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 9.00, current rows: 10.00. (TOO_MANY_ROWS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45078) (comment: 01801_approx_total_rows_mergetree_reverse.sql) (query 3, line 4) (in query: select * from data_01801 where key = 0 order by key settings max_rows_to_read=9 format Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f24bc97 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f24776e 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f247bac 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000003c166bc3 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1c31d7 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049298 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:47:57.868710 [ 9220 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 9.00, current rows: 10.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f24bc97 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f24776e 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f247bac 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000003c166bc3 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1c31d7 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049298 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:47:57.912975 [ 9220 ] {1bdf3afc-da45-4438-81c4-185d022c9ef7} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 9.00, current rows: 10.00. (TOO_MANY_ROWS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45078) (comment: 01801_approx_total_rows_mergetree_reverse.sql) (query 4, line 5) (in query: select * from data_01801 where key = 0 order by key desc settings max_rows_to_read=9 format Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f24bc97 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f24776e 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f247bac 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000003c166bc3 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1c31d7 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049298 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:47:57.916353 [ 9220 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 9.00, current rows: 10.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f24bc97 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f24776e 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f247bac 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000003c166bc3 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1c31d7 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049298 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:48:03.684072 [ 9229 ] {089ebc64-cd4a-4d66-bd5d-2c7cc1ae6277} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35756) (comment: 02015_shard_crash_clang_12_build.sh) (query 1, line 1) (in query: SELECT count() FROM distributed), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003adff16b 3. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003ade861b 4. ./build_docker/./src/Server/TCPHandler.cpp:1241: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe46c 5. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 08:48:03.688892 [ 9229 ] {089ebc64-cd4a-4d66-bd5d-2c7cc1ae6277} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:35756). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2557: DB::TCPHandler::sendException(DB::Exception const&, bool) @ 0x000000003adb5f67 7. ./build_docker/./src/Server/TCPHandler.cpp:825: DB::TCPHandler::runImpl() @ 0x000000003ad8f542 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:48:03.704497 [ 9229 ] {} TCPHandler: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003adff16b 3. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003ade861b 4. ./build_docker/./src/Server/TCPHandler.cpp:1241: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe46c 5. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 08:48:03.716075 [ 9262 ] {a84b13ad-61ca-4d55-9cfa-eea747fcf22b} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35734) (comment: 02015_shard_crash_clang_12_build.sh) (query 1, line 1) (in query: SELECT count() FROM distributed), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003adff16b 3. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003ade861b 4. ./build_docker/./src/Server/TCPHandler.cpp:1241: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe46c 5. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 08:48:03.737707 [ 9262 ] {a84b13ad-61ca-4d55-9cfa-eea747fcf22b} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:35734). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2557: DB::TCPHandler::sendException(DB::Exception const&, bool) @ 0x000000003adb5f67 7. ./build_docker/./src/Server/TCPHandler.cpp:825: DB::TCPHandler::runImpl() @ 0x000000003ad8f542 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:48:03.741055 [ 9262 ] {} TCPHandler: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003adff16b 3. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003ade861b 4. ./build_docker/./src/Server/TCPHandler.cpp:1241: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe46c 5. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 08:48:03.780071 [ 9249 ] {2ec7d7c4-b5e9-4603-bb30-44960144a87e} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:35810). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe68d 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:48:03.786322 [ 9249 ] {2ec7d7c4-b5e9-4603-bb30-44960144a87e} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:35810). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35810) (comment: 02015_shard_crash_clang_12_build.sh) (query 1, line 1) (in query: SELECT count() FROM distributed), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe68d 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:48:03.792293 [ 9249 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:35810). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe68d 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:48:03.838861 [ 2133 ] {b51dd48a-acce-41e6-9629-7f9a67419b6f} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:55746). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:55746) (comment: 02015_shard_crash_clang_12_build.sh) (query 1, line 1) (in query: SELECT count() AS `count()` FROM `test_6r7ajqyh`.`local` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:1421: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe992 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:48:03.847162 [ 2133 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:55746). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:1421: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe992 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:48:07.140000 [ 3255 ] {24d5d4e0-83e2-40ef-9916-bb0bc2484e28} executeQuery: Code: 475. DB::Exception: Incompatible types of WITH FILL expression values with column type Date. (INVALID_WITH_FILL_EXPRESSION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36054) (comment: 02561_with_fill_date_datetime_incompatible.sql) (query 1, line 1) (in query: SELECT today() AS a ORDER BY a ASC WITH FILL FROM now() - toIntervalMonth(1) TO now() + toIntervalDay(1) STEP 82600;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:261: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x000000003c010264 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr, bool const&, 0>(std::allocator const&, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x000000003c00534e 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl[abi:ne190107] (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x000000003c004765 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f132626 8. ./build_docker/./src/QueryPipeline/Pipe.cpp:632: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f131799 9. ./build_docker/./src/QueryPipeline/QueryPipelineBuilder.cpp:135: DB::QueryPipelineBuilder::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f18a721 10. ./build_docker/./src/Processors/QueryPlan/FillingStep.cpp:50: DB::FillingStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0031f4 11. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049e11 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:48:07.143225 [ 3255 ] {} TCPHandler: Code: 475. DB::Exception: Incompatible types of WITH FILL expression values with column type Date. (INVALID_WITH_FILL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:261: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x000000003c010264 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr, bool const&, 0>(std::allocator const&, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x000000003c00534e 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl[abi:ne190107] (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x000000003c004765 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f132626 8. ./build_docker/./src/QueryPipeline/Pipe.cpp:632: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f131799 9. ./build_docker/./src/QueryPipeline/QueryPipelineBuilder.cpp:135: DB::QueryPipelineBuilder::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f18a721 10. ./build_docker/./src/Processors/QueryPlan/FillingStep.cpp:50: DB::FillingStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0031f4 11. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049e11 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:48:09.874937 [ 2133 ] {b9bcd5d7-5722-43ed-a1f8-9c9082129155} executeQuery: Code: 57. DB::Exception: Table test_lazy_01294_concurrent_test_splqw84i.slog already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36298) (comment: 01294_lazy_database_concurrent_recreate_reattach_and_show_tables_long.sh) (query 1, line 2) (in query: ATTACH TABLE test_lazy_01294_concurrent_test_splqw84i.slog;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291ff91 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 08:48:09.893576 [ 2133 ] {} TCPHandler: Code: 57. DB::Exception: Table test_lazy_01294_concurrent_test_splqw84i.slog already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291ff91 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 08:48:11.639029 [ 9259 ] {d1b3f851-5d44-46d6-b91b-987eb0f5860a} executeQuery: Code: 60. DB::Exception: Table `test_lazy_01294_concurrent_test_splqw84i`.`tlog2` doesn't exist.: Cannot create table from metadata file metadata/test_lazy_01294_concurrent_test_splqw84i/tlog2.sql. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36464) (comment: 01294_lazy_database_concurrent_recreate_reattach_and_show_tables_long.sh) (query 1, line 1) (in query: SYSTEM STOP TTL MERGES test_lazy_01294_concurrent_test_splqw84i.tlog2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/DatabaseLazy.cpp:290: DB::DatabaseLazy::loadTable(String const&) const @ 0x000000002fa547ab 5. ./build_docker/./src/Databases/DatabaseLazy.cpp:157: DB::DatabaseLazy::tryGetTable(String const&) const @ 0x000000002fa51347 6. ./src/Databases/DatabaseLazy.h:60: DB::DatabaseLazy::tryGetTable(String const&, std::shared_ptr) const @ 0x000000002fa63b0c 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:451: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319fa4fe 8. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:984: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e419 9. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:228: DB::InterpreterSystemQuery::startStopAction(unsigned long, bool) @ 0x00000000337d9711 10. ./src/Common/Stopwatch.h:0: DB::InterpreterSystemQuery::execute() @ 0x00000000337e63d9 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:48:11.645601 [ 9259 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_lazy_01294_concurrent_test_splqw84i`.`tlog2` doesn't exist.: Cannot create table from metadata file metadata/test_lazy_01294_concurrent_test_splqw84i/tlog2.sql. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/DatabaseLazy.cpp:290: DB::DatabaseLazy::loadTable(String const&) const @ 0x000000002fa547ab 5. ./build_docker/./src/Databases/DatabaseLazy.cpp:157: DB::DatabaseLazy::tryGetTable(String const&) const @ 0x000000002fa51347 6. ./src/Databases/DatabaseLazy.h:60: DB::DatabaseLazy::tryGetTable(String const&, std::shared_ptr) const @ 0x000000002fa63b0c 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:451: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319fa4fe 8. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:984: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e419 9. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:228: DB::InterpreterSystemQuery::startStopAction(unsigned long, bool) @ 0x00000000337d9711 10. ./src/Common/Stopwatch.h:0: DB::InterpreterSystemQuery::execute() @ 0x00000000337e63d9 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:48:12.438408 [ 4466 ] {dc925313-442b-462a-930b-2cc7774b2bc1} executeQuery: Code: 42. DB::Exception: Function arrayPartialSort needs at least 2 arguments, passed 1: In scope SELECT arrayPartialSort([1, 2, 3]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36222) (comment: 00390_array_sort.sql) (query 30, line 49) (in query: SELECT arrayPartialSort([1,2,3]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, char const*&&, unsigned long&&) @ 0x000000001b1220bf 4. DB::FunctionArrayMapped, DB::NameArrayPartialSort>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b181aac 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:48:12.441638 [ 4466 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayPartialSort needs at least 2 arguments, passed 1: In scope SELECT arrayPartialSort([1, 2, 3]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, char const*&&, unsigned long&&) @ 0x000000001b1220bf 4. DB::FunctionArrayMapped, DB::NameArrayPartialSort>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b181aac 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:48:12.733165 [ 4466 ] {1d7c1993-6e47-4739-869b-4e19c690a2b6} executeQuery: Code: 43. DB::Exception: First argument for function arrayPartialSort must be a function. Actual UInt8: In scope SELECT arrayPartialSort(2, [1, 2, 3], [1]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36222) (comment: 00390_array_sort.sql) (query 31, line 50) (in query: SELECT arrayPartialSort(2, [1,2,3], [1]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::FunctionArrayMapped, DB::NameArrayPartialSort>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b1815c8 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:48:12.736150 [ 4466 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayPartialSort must be a function. Actual UInt8: In scope SELECT arrayPartialSort(2, [1, 2, 3], [1]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::FunctionArrayMapped, DB::NameArrayPartialSort>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b1815c8 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:48:12.768281 [ 4466 ] {c05fb4f9-bbea-44ff-8700-0adf81e2146f} executeQuery: Code: 43. DB::Exception: First argument for function arrayPartialSort must be a function. Actual UInt8: In scope SELECT arrayPartialSort(2, [1, 2, 3], 3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36222) (comment: 00390_array_sort.sql) (query 32, line 51) (in query: SELECT arrayPartialSort(2, [1,2,3], 3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::FunctionArrayMapped, DB::NameArrayPartialSort>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b1815c8 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:48:12.773709 [ 4466 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayPartialSort must be a function. Actual UInt8: In scope SELECT arrayPartialSort(2, [1, 2, 3], 3). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::FunctionArrayMapped, DB::NameArrayPartialSort>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b1815c8 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:48:13.075248 [ 4466 ] {f6aa3d05-9f47-45a6-b46f-0a0af074f997} executeQuery: Code: 43. DB::Exception: Illegal type Array(UInt8) of limit argument of function arrayPartialSort (must be UInt or Int): In scope SELECT arrayPartialSort(arraySort([1, 2, 3]), [1, 2, 3]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36222) (comment: 00390_array_sort.sql) (query 33, line 52) (in query: SELECT arrayPartialSort(arraySort([1,2,3]), [1,2,3]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a1f836d 4. DB::ArraySortImpl::checkArguments(String const&, DB::ColumnWithTypeAndName const*) requires DB::ArraySortImpl::num_fixed_params @ 0x000000001b1855d6 5. DB::FunctionArrayMapped, DB::NameArrayPartialSort>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b180806 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:48:13.082956 [ 4466 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(UInt8) of limit argument of function arrayPartialSort (must be UInt or Int): In scope SELECT arrayPartialSort(arraySort([1, 2, 3]), [1, 2, 3]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a1f836d 4. DB::ArraySortImpl::checkArguments(String const&, DB::ColumnWithTypeAndName const*) requires DB::ArraySortImpl::num_fixed_params @ 0x000000001b1855d6 5. DB::FunctionArrayMapped, DB::NameArrayPartialSort>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b180806 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:48:13.440621 [ 4466 ] {fe7c7342-993d-46ad-a4ec-b6fea0c2286f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Array(UInt8)) of limit argument of function arrayPartialSort (must be UInt or Int): In scope SELECT arrayMap(x -> range(x), [4, 1, 2, 3]) AS arr, 100 AS lim, arrayResize(arrayPartialSort(arrayPartialSort(lim, arr), arr), lim), arrayResize(arrayPartialReverseSort(lim, arr), lim), arrayResize(arrayPartialSort(x -> (-length(x)), lim, arr), lim). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36222) (comment: 00390_array_sort.sql) (query 34, line 53) (in query: SELECT arrayMap(x -> range(x), [4, 1, 2, 3]) AS arr, 100 AS lim, arrayResize(arrayPartialSort(arrayPartialSort(lim, arr), arr), lim), arrayResize(arrayPartialReverseSort(lim, arr), lim), arrayResize(arrayPartialSort(x -> (-length(x)), lim, arr), lim);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a1f836d 4. DB::ArraySortImpl::checkArguments(String const&, DB::ColumnWithTypeAndName const*) requires DB::ArraySortImpl::num_fixed_params @ 0x000000001b1855d6 5. DB::FunctionArrayMapped, DB::NameArrayPartialSort>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b180806 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 2025.06.13 08:48:13.461956 [ 4466 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Array(UInt8)) of limit argument of function arrayPartialSort (must be UInt or Int): In scope SELECT arrayMap(x -> range(x), [4, 1, 2, 3]) AS arr, 100 AS lim, arrayResize(arrayPartialSort(arrayPartialSort(lim, arr), arr), lim), arrayResize(arrayPartialReverseSort(lim, arr), lim), arrayResize(arrayPartialSort(x -> (-length(x)), lim, arr), lim). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a1f836d 4. DB::ArraySortImpl::checkArguments(String const&, DB::ColumnWithTypeAndName const*) requires DB::ArraySortImpl::num_fixed_params @ 0x000000001b1855d6 5. DB::FunctionArrayMapped, DB::NameArrayPartialSort>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b180806 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 2025.06.13 08:48:13.778193 [ 4466 ] {904e41e1-4703-4e5c-8b09-e96e67944515} executeQuery: Code: 386. DB::Exception: There is no supertype for types UInt16, Int8, UInt8, String, UInt64 because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36222) (comment: 00390_array_sort.sql) (query 35, line 54) (in query: SELECT arrayPartialReverseSort(arraySort((x, y) -> y, [NULL, NULL], [NULL, NULL]), arr), arrayMap(x -> toString(x), [257, -9223372036854775807, 2, -2147483648, 2147483648, NULL, 65536, -2147483648, 2, 65535]) AS arr, NULL, 100 AS lim, 65536, arrayResize(arrayPartialSort(x -> reverse(x), lim, arr), lim) GROUP BY [NULL, 1023, -2, NULL, 255, '0', NULL, 9223372036854775806] WITH ROLLUP;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f4977a2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f4a61a0 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:517: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f4a37bb 6. ./build_docker/./src/DataTypes/FieldToDataType.cpp:170: DB::FieldToDataType<(DB::LeastSupertypeOnError)0>::operator()(DB::Array const&) const @ 0x000000002f3fcb98 7. auto DB::Field::dispatch, DB::Field&>(DB::FieldToDataType<(DB::LeastSupertypeOnError)0>&&, DB::Field&) @ 0x000000000f0877b0 8. ./src/Common/FieldVisitors.h:24: DB::ConstantNode::ConstantNode(DB::Field) @ 0x000000002ffcb83e 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Field const&, 0>(std::allocator const&, DB::Field const&) @ 0x00000000302a4def 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003026415b 11. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:588: DB::(anonymous namespace)::QueryTreeBuilder::buildExpressionList(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030260ffc 12. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:383: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030277446 13. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003025ed8a 14. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003026a541 15. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003025ea82 16. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000003025d3c8 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae30f2 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:48:13.783019 [ 4466 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types UInt16, Int8, UInt8, String, UInt64 because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f4977a2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f4a61a0 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:517: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f4a37bb 6. ./build_docker/./src/DataTypes/FieldToDataType.cpp:170: DB::FieldToDataType<(DB::LeastSupertypeOnError)0>::operator()(DB::Array const&) const @ 0x000000002f3fcb98 7. auto DB::Field::dispatch, DB::Field&>(DB::FieldToDataType<(DB::LeastSupertypeOnError)0>&&, DB::Field&) @ 0x000000000f0877b0 8. ./src/Common/FieldVisitors.h:24: DB::ConstantNode::ConstantNode(DB::Field) @ 0x000000002ffcb83e 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Field const&, 0>(std::allocator const&, DB::Field const&) @ 0x00000000302a4def 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003026415b 11. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:588: DB::(anonymous namespace)::QueryTreeBuilder::buildExpressionList(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030260ffc 12. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:383: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030277446 13. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003025ed8a 14. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003026a541 15. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003025ea82 16. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000003025d3c8 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae30f2 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:48:14.034747 [ 9237 ] {96f82b8c-1c1a-484b-bf47-8d991c1a8ff7} executeQuery: Code: 36. DB::Exception: Override not allowed for 'url'. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36598) (comment: 02883_named_collections_override.sh) (query 10, line 19) (in query: SELECT * FROM url(02883_named_collections_override_test_dglh15pz_collection1, url='http://127.0.0.1:8123?query=select+2');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:144: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x00000000382d1bfd 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:59: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002661ac5b 6. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:52: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000026610f7d 7. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:54: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002661a7e6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:48:14.038490 [ 9237 ] {} TCPHandler: Code: 36. DB::Exception: Override not allowed for 'url'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:144: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x00000000382d1bfd 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:59: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002661ac5b 6. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:52: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000026610f7d 7. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:54: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002661a7e6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:48:14.537711 [ 3255 ] {9d10a979-cefb-4404-a0c9-4464a750fa4c} executeQuery: Code: 36. DB::Exception: All numbers in both samples are identical: While executing ConvertingAggregatedToChunksTransform. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43846) (comment: 01560_mann_whitney.sql) (query 9, line 9) (in query: WITH mannWhitneyUTest('two-sided')(1, right) AS pair SELECT roundBankers(pair.1, 16) AS t_stat, roundBankers(pair.2, 16) AS p_value FROM mann_whitney_test;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./src/AggregateFunctions/StatCommon.h:51: DB::(anonymous namespace)::AggregateFunctionMannWhitney::insertResultInto(char*, DB::IColumn&, DB::Arena*) const @ 0x0000000025c70deb 5. ./build_docker/./src/Interpreters/Aggregator.cpp:1908: void DB::Aggregator::insertAggregatesIntoColumns(char*&, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::Arena*) const @ 0x0000000031df7cb0 6. ./build_docker/./src/Interpreters/Aggregator.cpp:2265: DB::Aggregator::prepareBlockAndFillWithoutKey(DB::AggregatedDataVariants&, bool, bool) const @ 0x0000000031beb7c8 7. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:467: DB::ConvertingAggregatedToChunksTransform::initialize() @ 0x000000003b9c95db 8. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:299: DB::ConvertingAggregatedToChunksTransform::work() @ 0x000000003b9c0bde 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 08:48:14.554578 [ 3255 ] {} TCPHandler: Code: 36. DB::Exception: All numbers in both samples are identical: While executing ConvertingAggregatedToChunksTransform. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./src/AggregateFunctions/StatCommon.h:51: DB::(anonymous namespace)::AggregateFunctionMannWhitney::insertResultInto(char*, DB::IColumn&, DB::Arena*) const @ 0x0000000025c70deb 5. ./build_docker/./src/Interpreters/Aggregator.cpp:1908: void DB::Aggregator::insertAggregatesIntoColumns(char*&, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::Arena*) const @ 0x0000000031df7cb0 6. ./build_docker/./src/Interpreters/Aggregator.cpp:2265: DB::Aggregator::prepareBlockAndFillWithoutKey(DB::AggregatedDataVariants&, bool, bool) const @ 0x0000000031beb7c8 7. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:467: DB::ConvertingAggregatedToChunksTransform::initialize() @ 0x000000003b9c95db 8. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:299: DB::ConvertingAggregatedToChunksTransform::work() @ 0x000000003b9c0bde 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:48:16.299714 [ 9237 ] {b2cf1397-3784-4c9f-aa90-b7d68c641db5} executeQuery: Code: 36. DB::Exception: Override not allowed because setting allow_override_by_default is disabled. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36598) (comment: 02883_named_collections_override.sh) (query 20, line 30) (in query: SELECT * FROM url(02883_named_collections_override_test_dglh15pz_collection1, headers('Accept'='text/csv; charset=utf-8'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:141: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x00000000382d1d34 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:59: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002661ac5b 6. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:52: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000026610f7d 7. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:54: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002661a7e6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:48:16.303071 [ 9237 ] {} TCPHandler: Code: 36. DB::Exception: Override not allowed because setting allow_override_by_default is disabled. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:141: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x00000000382d1d34 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:59: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002661ac5b 6. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:52: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000026610f7d 7. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:54: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002661a7e6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:48:16.323802 [ 9237 ] {31b663ba-27af-42b1-9709-53b511675a26} executeQuery: Code: 36. DB::Exception: Override not allowed for 'url'. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36598) (comment: 02883_named_collections_override.sh) (query 21, line 31) (in query: SELECT * FROM url(02883_named_collections_override_test_dglh15pz_collection1, url='http://127.0.0.1:8123?query=select+2');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:144: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x00000000382d1bfd 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:59: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002661ac5b 6. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:52: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000026610f7d 7. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:54: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002661a7e6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:48:16.327374 [ 9237 ] {} TCPHandler: Code: 36. DB::Exception: Override not allowed for 'url'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:144: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x00000000382d1bfd 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:59: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002661ac5b 6. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:52: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000026610f7d 7. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:54: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002661a7e6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:48:16.988820 [ 9237 ] {709f9894-165e-4da6-8714-78b61e977ff5} executeQuery: Code: 36. DB::Exception: Override not allowed because setting allow_override_by_default is disabled. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36598) (comment: 02883_named_collections_override.sh) (query 25, line 35) (in query: SELECT * FROM url(02883_named_collections_override_test_dglh15pz_collection2, headers('Accept'='text/csv; charset=utf-8'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:141: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x00000000382d1d34 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:59: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002661ac5b 6. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:52: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000026610f7d 7. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:54: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002661a7e6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:48:17.005606 [ 9237 ] {} TCPHandler: Code: 36. DB::Exception: Override not allowed because setting allow_override_by_default is disabled. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:141: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x00000000382d1d34 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:59: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002661ac5b 6. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:52: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000026610f7d 7. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:54: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002661a7e6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:48:17.026523 [ 9237 ] {b10b5bf1-e251-4f1b-a5ed-6ca9dd3b0a26} executeQuery: Code: 36. DB::Exception: Override not allowed for 'url'. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36598) (comment: 02883_named_collections_override.sh) (query 26, line 36) (in query: SELECT * FROM url(02883_named_collections_override_test_dglh15pz_collection2, url='http://127.0.0.1:8123?query=select+2');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:144: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x00000000382d1bfd 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:59: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002661ac5b 6. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:52: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000026610f7d 7. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:54: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002661a7e6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:48:17.029890 [ 9237 ] {} TCPHandler: Code: 36. DB::Exception: Override not allowed for 'url'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:144: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x00000000382d1bfd 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:59: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002661ac5b 6. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:52: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000026610f7d 7. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:54: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002661a7e6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:48:17.050409 [ 9237 ] {88b4c554-f3e7-46c7-9fee-d5e8cdb1dd64} executeQuery: Code: 36. DB::Exception: Override not allowed for 'format'. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36598) (comment: 02883_named_collections_override.sh) (query 27, line 37) (in query: SELECT * FROM url(02883_named_collections_override_test_dglh15pz_collection2, format='CSV');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:144: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x00000000382d1bfd 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:59: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002661ac5b 6. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:52: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000026610f7d 7. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:54: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002661a7e6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:48:17.061288 [ 9237 ] {} TCPHandler: Code: 36. DB::Exception: Override not allowed for 'format'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:144: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x00000000382d1bfd 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:59: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002661ac5b 6. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:52: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000026610f7d 7. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:54: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002661a7e6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:48:17.582482 [ 9237 ] {37713b8e-2fd9-4a4a-b632-7177b5cdf76b} executeQuery: Code: 36. DB::Exception: Override not allowed for 'format'. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36598) (comment: 02883_named_collections_override.sh) (query 33, line 51) (in query: SELECT * FROM url(02883_named_collections_override_test_dglh15pz_collection3, format='CSV');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:144: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x00000000382d1bfd 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:59: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002661ac5b 6. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:52: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000026610f7d 7. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:54: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002661a7e6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:48:17.586137 [ 9237 ] {} TCPHandler: Code: 36. DB::Exception: Override not allowed for 'format'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:144: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x00000000382d1bfd 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:59: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002661ac5b 6. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:52: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000026610f7d 7. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:54: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002661a7e6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:48:18.256719 [ 9237 ] {b22e3ae2-6fee-4e5d-ade9-c43967b6dd84} executeQuery: Code: 36. DB::Exception: Override not allowed for 'url'. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36598) (comment: 02883_named_collections_override.sh) (query 42, line 63) (in query: SELECT * FROM url(url_override1, url='http://127.0.0.1:8123?query=select+2');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:144: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x00000000382d1bfd 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:59: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002661ac5b 6. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:52: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000026610f7d 7. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:54: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002661a7e6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:48:18.261561 [ 9237 ] {} TCPHandler: Code: 36. DB::Exception: Override not allowed for 'url'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:144: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x00000000382d1bfd 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:59: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002661ac5b 6. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:52: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000026610f7d 7. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:54: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002661a7e6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:48:20.167779 [ 9237 ] {acbac561-ae6e-4e66-9b3b-33fdd55c77cd} executeQuery: Code: 36. DB::Exception: Override not allowed because setting allow_override_by_default is disabled. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36598) (comment: 02883_named_collections_override.sh) (query 52, line 74) (in query: SELECT * FROM url(url_override1, headers('Accept'='text/csv; charset=utf-8'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:141: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x00000000382d1d34 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:59: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002661ac5b 6. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:52: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000026610f7d 7. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:54: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002661a7e6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:48:20.171932 [ 9237 ] {} TCPHandler: Code: 36. DB::Exception: Override not allowed because setting allow_override_by_default is disabled. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:141: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x00000000382d1d34 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:59: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002661ac5b 6. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:52: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000026610f7d 7. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:54: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002661a7e6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:48:20.197304 [ 9237 ] {07750d84-3a75-40a6-b87c-fe08e6d39896} executeQuery: Code: 36. DB::Exception: Override not allowed for 'url'. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36598) (comment: 02883_named_collections_override.sh) (query 53, line 75) (in query: SELECT * FROM url(url_override1, url='http://127.0.0.1:8123?query=select+2');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:144: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x00000000382d1bfd 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:59: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002661ac5b 6. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:52: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000026610f7d 7. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:54: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002661a7e6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:48:20.205087 [ 9237 ] {} TCPHandler: Code: 36. DB::Exception: Override not allowed for 'url'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:144: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x00000000382d1bfd 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:59: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002661ac5b 6. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:52: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000026610f7d 7. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:54: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002661a7e6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:48:20.672196 [ 3514 ] {2e0cfd68-3e25-4ffb-943b-56b2826edf39} executeQuery: Code: 62. DB::Exception: AUTO_INCREMENT is not supported. To ignore the keyword in column declaration, set `compatibility_ignore_auto_increment_in_create_table` to true. (SYNTAX_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44534) (comment: 02293_compatibility_ignore_auto_increment_in_create_table.sql) (query 5, line 10) (in query: CREATE TABLE ignore_auto_increment ( id int AUTO_INCREMENT ) ENGINE=MergeTree() ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:662: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000328d2569 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000328d60b9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000328fff5d 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 08:48:20.675393 [ 3514 ] {} TCPHandler: Code: 62. DB::Exception: AUTO_INCREMENT is not supported. To ignore the keyword in column declaration, set `compatibility_ignore_auto_increment_in_create_table` to true. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:662: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000328d2569 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000328d60b9 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000328fff5d 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 08:48:20.983625 [ 9237 ] {0b9f7adf-d67a-4622-9054-66338fcc9955} executeQuery: Code: 36. DB::Exception: Override not allowed because setting allow_override_by_default is disabled. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36598) (comment: 02883_named_collections_override.sh) (query 57, line 79) (in query: SELECT * FROM url(url_override2, headers('Accept'='text/csv; charset=utf-8'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:141: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x00000000382d1d34 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:59: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002661ac5b 6. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:52: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000026610f7d 7. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:54: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002661a7e6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:48:20.988639 [ 9237 ] {} TCPHandler: Code: 36. DB::Exception: Override not allowed because setting allow_override_by_default is disabled. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:141: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x00000000382d1d34 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:59: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002661ac5b 6. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:52: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000026610f7d 7. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:54: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002661a7e6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:48:21.026881 [ 9237 ] {0df9ca50-ff0d-4a0b-b4e8-c4fd31d38e5b} executeQuery: Code: 36. DB::Exception: Override not allowed for 'url'. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36598) (comment: 02883_named_collections_override.sh) (query 58, line 80) (in query: SELECT * FROM url(url_override2, url='http://127.0.0.1:8123?query=select+2');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:144: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x00000000382d1bfd 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:59: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002661ac5b 6. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:52: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000026610f7d 7. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:54: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002661a7e6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:48:21.032556 [ 9237 ] {} TCPHandler: Code: 36. DB::Exception: Override not allowed for 'url'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:144: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x00000000382d1bfd 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:59: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002661ac5b 6. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:52: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000026610f7d 7. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:54: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002661a7e6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:48:21.061286 [ 9237 ] {a153e463-ae8a-42ef-a42c-378ce9ca53d3} executeQuery: Code: 36. DB::Exception: Override not allowed for 'format'. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36598) (comment: 02883_named_collections_override.sh) (query 59, line 81) (in query: SELECT * FROM url(url_override2, format='CSV');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:144: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x00000000382d1bfd 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:59: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002661ac5b 6. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:52: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000026610f7d 7. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:54: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002661a7e6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:48:21.065338 [ 9237 ] {} TCPHandler: Code: 36. DB::Exception: Override not allowed for 'format'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:144: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x00000000382d1bfd 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:59: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002661ac5b 6. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:52: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000026610f7d 7. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:54: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002661a7e6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:48:21.606183 [ 9235 ] {70c582db-1754-4dcf-a477-3a3f1443397d} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `test_ispizuxj` in scope SELECT 'test_01194', test_ispizuxj, 1. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:39790) (comment: 01194_http_query_id.sh) (in query: SELECT 'test_01194',test_ispizuxj,1 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000303dd3a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032b465 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 18. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 19. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 20. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:48:21.614386 [ 9235 ] {70c582db-1754-4dcf-a477-3a3f1443397d} DynamicQueryHandler: Code: 47. DB::Exception: Unknown expression identifier `test_ispizuxj` in scope SELECT 'test_01194', test_ispizuxj, 1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000303dd3a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032b465 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 18. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 19. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 20. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:48:21.653072 [ 9235 ] {78ce1db2-672a-41e2-86b6-a753ed8d3468} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `test_ispizuxj` in scope SELECT 'test_01194', test_ispizuxj, 2. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:39800) (comment: 01194_http_query_id.sh) (in query: SELECT 'test_01194',test_ispizuxj,2 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000303dd3a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032b465 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 18. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 19. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 20. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:48:21.656044 [ 9235 ] {78ce1db2-672a-41e2-86b6-a753ed8d3468} DynamicQueryHandler: Code: 47. DB::Exception: Unknown expression identifier `test_ispizuxj` in scope SELECT 'test_01194', test_ispizuxj, 2. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000303dd3a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032b465 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 18. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 19. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 20. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:48:21.720046 [ 9259 ] {25d85118-e49a-45f1-a0ad-488e52338761} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `test_ispizuxj` in scope SELECT 'test_01194', test_ispizuxj, 3. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:39816) (comment: 01194_http_query_id.sh) (in query: SELECT 'test_01194',test_ispizuxj,3), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000303dd3a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032b465 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 18. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 19. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 20. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:48:21.722661 [ 9259 ] {25d85118-e49a-45f1-a0ad-488e52338761} DynamicQueryHandler: Code: 47. DB::Exception: Unknown expression identifier `test_ispizuxj` in scope SELECT 'test_01194', test_ispizuxj, 3. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000303dd3a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032b465 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 18. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 19. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 20. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:48:21.785995 [ 2133 ] {86b19bbb-a97b-465e-9612-93d58becba7c} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `test_ispizuxj` in scope SELECT 'test_01194', test_ispizuxj, 4. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:39828) (comment: 01194_http_query_id.sh) (in query: SELECT 'test_01194',test_ispizuxj,4), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000303dd3a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032b465 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 18. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 19. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 20. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:48:21.793697 [ 2133 ] {86b19bbb-a97b-465e-9612-93d58becba7c} DynamicQueryHandler: Code: 47. DB::Exception: Unknown expression identifier `test_ispizuxj` in scope SELECT 'test_01194', test_ispizuxj, 4. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000303dd3a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032b465 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 18. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 19. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 20. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:48:23.296685 [ 9259 ] {e9455992-3cb9-4cbf-8971-0c555d55ca8b} executeQuery: Code: 190. DB::Exception: Lengths of all arrays passed to arrayEnumerateDense must be equal.: while executing 'FUNCTION arrayEnumerateDense(_CAST([]_Array(Nothing), 'Array(Nothing)'_String) :: 1, array(nothingNull(_CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String))) :: 2) -> arrayEnumerateDense(_CAST([]_Array(Nothing), 'Array(Nothing)'_String), array(nothingNull(_CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String)))) Array(UInt32) : 0'. (SIZES_OF_ARRAYS_DONT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44766) (comment: 00808_array_enumerate_segfault.sql) (query 3, line 3) (in query: SELECT arrayEnumerateDense([], [sequenceCount(NULL)]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::FunctionArrayEnumerateExtended::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001dcc784d 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:48:23.333682 [ 9259 ] {} TCPHandler: Code: 190. DB::Exception: Lengths of all arrays passed to arrayEnumerateDense must be equal.: while executing 'FUNCTION arrayEnumerateDense(_CAST([]_Array(Nothing), 'Array(Nothing)'_String) :: 1, array(nothingNull(_CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String))) :: 2) -> arrayEnumerateDense(_CAST([]_Array(Nothing), 'Array(Nothing)'_String), array(nothingNull(_CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String)))) Array(UInt32) : 0'. (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::FunctionArrayEnumerateExtended::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001dcc784d 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:48:24.818774 [ 9249 ] {109b09c5-46b8-42b4-96a8-90e1274a739c} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(groupArray(9223372036854775807), UInt32) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: groupArray instead of groupArray. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33220) (comment: 01632_group_array_msan.sql) (query 1, line 1) (in query: SELECT groupArrayMerge(1048577)(y * 1048576) FROM (SELECT groupArrayState(9223372036854775807)(x) AS y FROM (SELECT 1048576 AS x)) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:67: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x000000002651d259 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002d00a044 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303855f9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 29. ? @ 0x00007f5206343ac3 30. ? @ 0x00007f52063d5850 2025.06.13 08:48:24.829046 [ 9249 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(groupArray(9223372036854775807), UInt32) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: groupArray instead of groupArray. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:67: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x000000002651d259 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002d00a044 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303855f9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 29. ? @ 0x00007f5206343ac3 30. ? @ 0x00007f52063d5850 2025.06.13 08:48:24.920565 [ 2135 ] {1a8cbb47-5b7b-42e7-9969-7a7da5947677} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(min, UInt8) of argument for aggregate function groupBitmapAnd. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33142) (comment: 02429_groupBitmap_chain_state.sql) (query 3, line 4) (in query: SELECT groupBitmapAnd(z) FROM ( SELECT minState(u) AS z FROM ( SELECT 123 AS u ) AS a1 ) AS a2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a1f836d 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupBitmap.cpp:259: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionBitmapL2(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000255b86c2 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000203d4b63 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d009bfb 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303855f9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 08:48:24.924880 [ 2135 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(min, UInt8) of argument for aggregate function groupBitmapAnd. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a1f836d 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupBitmap.cpp:259: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionBitmapL2(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000255b86c2 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000203d4b63 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d009bfb 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303855f9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 08:48:25.227146 [ 2135 ] {3130fc44-a8c5-4970-8797-b9a6cb2d095c} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(max, String) of argument for aggregate function groupBitmapOr. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33142) (comment: 02429_groupBitmap_chain_state.sql) (query 4, line 5) (in query: SELECT groupBitmapOr(z) FROM ( SELECT maxState(u) AS z FROM ( SELECT '123' AS u ) AS a1 ) AS a2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a1f836d 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupBitmap.cpp:259: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionBitmapL2(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000255c1042 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000203d4b63 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d009bfb 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303855f9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 08:48:25.230894 [ 2135 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(max, String) of argument for aggregate function groupBitmapOr. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a1f836d 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupBitmap.cpp:259: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionBitmapL2(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000255c1042 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000203d4b63 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d009bfb 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303855f9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 08:48:25.503326 [ 2135 ] {19f686b8-3eb6-44e7-a0c9-18bddd87d19a} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(count) of argument for aggregate function groupBitmapXor. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33142) (comment: 02429_groupBitmap_chain_state.sql) (query 5, line 6) (in query: SELECT groupBitmapXor(z) FROM ( SELECT countState() AS z FROM ( SELECT '123' AS u ) AS a1 ) AS a2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a1f836d 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupBitmap.cpp:259: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionBitmapL2(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000255c99c2 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000203d4b63 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d009bfb 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303855f9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 08:48:25.507099 [ 2135 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(count) of argument for aggregate function groupBitmapXor. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a1f836d 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupBitmap.cpp:259: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionBitmapL2(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000255c99c2 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000203d4b63 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d009bfb 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303855f9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 08:48:25.702292 [ 9249 ] {e369394d-3aa5-4fb3-a213-0e1efda6bf21} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(quantileResample(0.1, 1, 2, 42), UInt64, UInt64) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: quantileResample instead of quantileResample. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33220) (comment: 01632_group_array_msan.sql) (query 4, line 4) (in query: SELECT quantileResampleMerge(0.5, 257, 65536, 1)(tuple(*).1) FROM (SELECT quantileResampleState(0.10, 1, 2, 42)(number, number) FROM numbers(100));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:67: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x000000002651d259 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002d00a044 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303855f9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 29. ? @ 0x00007f5206343ac3 30. ? @ 0x00007f52063d5850 2025.06.13 08:48:25.706299 [ 9249 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(quantileResample(0.1, 1, 2, 42), UInt64, UInt64) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: quantileResample instead of quantileResample. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:67: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x000000002651d259 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002d00a044 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303855f9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 29. ? @ 0x00007f5206343ac3 30. ? @ 0x00007f52063d5850 2025.06.13 08:48:26.729237 [ 9246 ] {504b64cb-ed1c-4d4c-9405-342db3b1c97d} executeQuery: Code: 128. DB::Exception: Array size 96142475 with element size 21 bytes is too large: while executing function arrayWithConstant: In scope SELECT arrayWithConstant(96142475, ['qMUF']). (TOO_LARGE_ARRAY_SIZE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33390) (comment: 03216_arrayWithConstant_limits.sql) (query 1, line 1) (in query: SELECT arrayWithConstant(96142475, ['qMUF']);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, long&, unsigned long&, String&&) @ 0x000000001e6c2897 4. DB::FunctionArrayWithConstant::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001e6c1d2a 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 08:48:26.733958 [ 9246 ] {} TCPHandler: Code: 128. DB::Exception: Array size 96142475 with element size 21 bytes is too large: while executing function arrayWithConstant: In scope SELECT arrayWithConstant(96142475, ['qMUF']). (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, long&, unsigned long&, String&&) @ 0x000000001e6c2897 4. DB::FunctionArrayWithConstant::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001e6c1d2a 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 08:48:27.017369 [ 9246 ] {9341bc43-39c0-449c-8436-c67358422772} executeQuery: Code: 128. DB::Exception: Array size 100000000 with element size 102 bytes is too large: while executing function arrayWithConstant: while executing 'FUNCTION arrayWithConstant(100000000_UInt32 :: 1, materialize(_CAST([[[[[[[[[['Hello, world!']]]]]]]]]]_Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(String)))))))))), 'Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(String))))))))))'_String)) :: 3) -> arrayWithConstant(100000000_UInt32, materialize(_CAST([[[[[[[[[['Hello, world!']]]]]]]]]]_Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(String)))))))))), 'Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(String))))))))))'_String))) Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(String))))))))))) : 2'. (TOO_LARGE_ARRAY_SIZE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33390) (comment: 03216_arrayWithConstant_limits.sql) (query 2, line 2) (in query: SELECT arrayWithConstant(100000000, materialize([[[[[[[[[['Hello, world!']]]]]]]]]]));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, long&, unsigned long&, String&&) @ 0x000000001e6c2897 4. DB::FunctionArrayWithConstant::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001e6c1d2a 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:48:27.024769 [ 9246 ] {} TCPHandler: Code: 128. DB::Exception: Array size 100000000 with element size 102 bytes is too large: while executing function arrayWithConstant: while executing 'FUNCTION arrayWithConstant(100000000_UInt32 :: 1, materialize(_CAST([[[[[[[[[['Hello, world!']]]]]]]]]]_Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(String)))))))))), 'Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(String))))))))))'_String)) :: 3) -> arrayWithConstant(100000000_UInt32, materialize(_CAST([[[[[[[[[['Hello, world!']]]]]]]]]]_Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(String)))))))))), 'Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(String))))))))))'_String))) Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(String))))))))))) : 2'. (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, long&, unsigned long&, String&&) @ 0x000000001e6c2897 4. DB::FunctionArrayWithConstant::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001e6c1d2a 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:48:28.049711 [ 2136 ] {1339123c-98f1-4977-9c8e-cfcec65f2b2a} executeQuery: Code: 42. DB::Exception: Number of arguments for function generateSerialID doesn't match: passed 0, should be 1: In scope SELECT generateSerialID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33502) (comment: 03129_serial_test_zookeeper.sql) (query 5, line 8) (in query: SELECT generateSerialID();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8700 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 08:48:28.053672 [ 2136 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function generateSerialID doesn't match: passed 0, should be 1: In scope SELECT generateSerialID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8700 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 08:48:28.074886 [ 2136 ] {7b23c9fa-0890-4700-a1cf-1f392711bd6e} executeQuery: Code: 42. DB::Exception: Number of arguments for function generateSerialID doesn't match: passed 2, should be 1: In scope SELECT generateSerialID('x', 'y'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33502) (comment: 03129_serial_test_zookeeper.sql) (query 6, line 9) (in query: SELECT generateSerialID('x', 'y');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8700 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 08:48:28.081134 [ 2136 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function generateSerialID doesn't match: passed 2, should be 1: In scope SELECT generateSerialID('x', 'y'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8700 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 08:48:28.378663 [ 2136 ] {429339b2-b1f0-449c-952d-827fbb4707c7} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'series_identifier' to function 'generateSerialID'. Expected: const String, got: UInt8: In scope SELECT generateSerialID(1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33502) (comment: 03129_serial_test_zookeeper.sql) (query 7, line 10) (in query: SELECT generateSerialID(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c037e87 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c0312c1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c02fb7f 6. DB::(anonymous namespace)::FunctionSerial::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f03532d 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:48:28.382383 [ 2136 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'series_identifier' to function 'generateSerialID'. Expected: const String, got: UInt8: In scope SELECT generateSerialID(1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c037e87 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c0312c1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c02fb7f 6. DB::(anonymous namespace)::FunctionSerial::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f03532d 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:48:28.408184 [ 2136 ] {b6a4e774-4797-4dcd-8d00-f22126f8c60f} executeQuery: Code: 44. DB::Exception: A value of illegal type was provided as 1st argument 'series_identifier' to function 'generateSerialID'. Expected: const String, got: String: In scope SELECT generateSerialID(materialize('x')). (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33502) (comment: 03129_serial_test_zookeeper.sql) (query 8, line 11) (in query: SELECT generateSerialID(materialize('x'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c037e87 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c0312c1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c02fb7f 6. DB::(anonymous namespace)::FunctionSerial::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f03532d 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:48:28.412290 [ 2136 ] {} TCPHandler: Code: 44. DB::Exception: A value of illegal type was provided as 1st argument 'series_identifier' to function 'generateSerialID'. Expected: const String, got: String: In scope SELECT generateSerialID(materialize('x')). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c037e87 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c0312c1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c02fb7f 6. DB::(anonymous namespace)::FunctionSerial::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f03532d 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:48:28.668989 [ 2136 ] {246e9a6f-fee4-48ff-8b77-2f678b1cc101} executeQuery: Code: 36. DB::Exception: Series name 'abcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghij' is too long. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33502) (comment: 03129_serial_test_zookeeper.sql) (query 9, line 12) (in query: SELECT generateSerialID('abcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghij');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. DB::(anonymous namespace)::FunctionSerial::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f0346b8 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301087b6 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000030104ffd 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003ba0ea77 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003bfff312 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032b1845f 15. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x0000000032b01504 16. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:48:28.671977 [ 2136 ] {} TCPHandler: Code: 36. DB::Exception: Series name 'abcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghij' is too long. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. DB::(anonymous namespace)::FunctionSerial::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f0346b8 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301087b6 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000030104ffd 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003ba0ea77 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003bfff312 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032b1845f 15. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x0000000032b01504 16. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:48:29.063209 [ 2136 ] {9c8c9dd1-c89e-4ab8-80a3-1027a8f989a1} executeQuery: Code: 290. DB::Exception: Too many series created by generateSerialID function, maximum: 3. This is controlled by the `max_autoincrement_series` setting. (LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33502) (comment: 03129_serial_test_zookeeper.sql) (query 12, line 18) (in query: SELECT generateSerialID('a');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, unsigned long const&) @ 0x000000000f03668d 4. DB::(anonymous namespace)::FunctionSerial::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f0333bb 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301087b6 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000030104ffd 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003ba0ea77 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003bfff312 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032b1845f 15. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x0000000032b01504 16. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:48:29.066988 [ 2136 ] {} TCPHandler: Code: 290. DB::Exception: Too many series created by generateSerialID function, maximum: 3. This is controlled by the `max_autoincrement_series` setting. (LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, unsigned long const&) @ 0x000000000f03668d 4. DB::(anonymous namespace)::FunctionSerial::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f0333bb 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301087b6 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000030104ffd 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003ba0ea77 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003bfff312 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032b1845f 15. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x0000000032b01504 16. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:48:30.756457 [ 3255 ] {53d08030-eea1-471c-b1db-93aa9591cf87} executeQuery: Code: 57. DB::Exception: Table test_lazy_01294_concurrent_test_splqw84i.log already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33738) (comment: 01294_lazy_database_concurrent_recreate_reattach_and_show_tables_long.sh) (query 1, line 1) (in query: ATTACH TABLE test_lazy_01294_concurrent_test_splqw84i.log;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291ff91 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 08:48:30.761114 [ 3255 ] {} TCPHandler: Code: 57. DB::Exception: Table test_lazy_01294_concurrent_test_splqw84i.log already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291ff91 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 08:48:32.304594 [ 2133 ] {f8387497-184f-401c-b46e-a7f75f8b896b} executeQuery: Code: 57. DB::Exception: Table test_lazy_01294_concurrent_test_splqw84i.tlog already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33818) (comment: 01294_lazy_database_concurrent_recreate_reattach_and_show_tables_long.sh) (query 1, line 1) (in query: ATTACH TABLE test_lazy_01294_concurrent_test_splqw84i.tlog;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291ff91 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 08:48:32.309918 [ 2133 ] {} TCPHandler: Code: 57. DB::Exception: Table test_lazy_01294_concurrent_test_splqw84i.tlog already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291ff91 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 08:48:35.363052 [ 2135 ] {f2f4fbc2-046b-43f6-8f00-a1930baa449c} executeQuery: Code: 57. DB::Exception: Table test_lazy_01294_concurrent_test_splqw84i.tlog2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57888) (comment: 01294_lazy_database_concurrent_recreate_reattach_and_show_tables_long.sh) (query 1, line 1) (in query: ATTACH TABLE test_lazy_01294_concurrent_test_splqw84i.tlog2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291ff91 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 08:48:35.370021 [ 2135 ] {} TCPHandler: Code: 57. DB::Exception: Table test_lazy_01294_concurrent_test_splqw84i.tlog2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291ff91 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 08:48:39.162740 [ 9260 ] {8daef2e4-a1e4-4a52-90f2-be85c6967dbe} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function gcd: In scope SELECT gcd(1280.1, 1024.1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58028) (comment: 00515_gcd_lcm.sql) (query 24, line 26) (in query: -- test gcd float select gcd(1280.1, 1024.1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000efe71f6 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000edcd879 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a174126 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:48:39.165695 [ 9260 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function gcd: In scope SELECT gcd(1280.1, 1024.1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000efe71f6 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000edcd879 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a174126 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:48:39.181758 [ 9260 ] {72ad23b2-82c1-4e99-9b3d-be4cadb76ee7} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function gcd: In scope SELECT gcd(11.1, 121.1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58028) (comment: 00515_gcd_lcm.sql) (query 25, line 28) (in query: select gcd(11.1, 121.1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000efe71f6 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000edcd879 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a174126 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:48:39.185071 [ 9260 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function gcd: In scope SELECT gcd(11.1, 121.1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000efe71f6 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000edcd879 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a174126 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:48:39.202184 [ 9260 ] {de095e34-98fa-4833-8e61-fcb1d691e601} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function gcd: In scope SELECT gcd(-256.1, 64.1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58028) (comment: 00515_gcd_lcm.sql) (query 26, line 29) (in query: select gcd(-256.1, 64.1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000efe71f6 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000edcd879 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a174126 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:48:39.205022 [ 9260 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function gcd: In scope SELECT gcd(-256.1, 64.1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000efe71f6 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000edcd879 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a174126 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:48:39.222558 [ 9260 ] {20cd53a8-6d34-4410-90b8-8bbcedeede1d} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function gcd: In scope SELECT gcd(1.1, 1.1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58028) (comment: 00515_gcd_lcm.sql) (query 27, line 30) (in query: select gcd(1.1, 1.1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000efe71f6 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000edcd879 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a174126 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:48:39.225517 [ 9260 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function gcd: In scope SELECT gcd(1.1, 1.1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000efe71f6 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000edcd879 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a174126 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:48:39.243210 [ 9260 ] {8bfde1e1-77dc-408a-954e-de0e7e9e266f} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function gcd: In scope SELECT gcd(4.1, 2.1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58028) (comment: 00515_gcd_lcm.sql) (query 28, line 31) (in query: select gcd(4.1, 2.1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000efe71f6 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000edcd879 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a174126 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:48:39.246219 [ 9260 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function gcd: In scope SELECT gcd(4.1, 2.1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000efe71f6 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000edcd879 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a174126 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:48:39.266238 [ 9260 ] {127d4d54-7237-44f2-a069-bb0430e87bce} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function gcd: In scope SELECT gcd(15.1, 49.1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58028) (comment: 00515_gcd_lcm.sql) (query 29, line 32) (in query: select gcd(15.1, 49.1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000efe71f6 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000edcd879 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a174126 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:48:39.269604 [ 9260 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function gcd: In scope SELECT gcd(15.1, 49.1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000efe71f6 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000edcd879 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a174126 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:48:39.290190 [ 9260 ] {7aef37ec-45ae-4370-a96f-7d458226e1d9} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function gcd: In scope SELECT gcd(255.1, 254.1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58028) (comment: 00515_gcd_lcm.sql) (query 30, line 33) (in query: select gcd(255.1, 254.1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000efe71f6 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000edcd879 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a174126 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:48:39.294262 [ 9260 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function gcd: In scope SELECT gcd(255.1, 254.1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000efe71f6 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000edcd879 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a174126 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:48:39.599435 [ 9260 ] {268e5a1c-dd90-4903-8472-2500c7028f37} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(1280.1, 1024.1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58028) (comment: 00515_gcd_lcm.sql) (query 31, line 34) (in query: -- test lcm float select lcm(1280.1, 1024.1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000012ace216 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000128999f9 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a174126 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:48:39.602457 [ 9260 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(1280.1, 1024.1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000012ace216 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000128999f9 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a174126 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:48:39.617646 [ 9260 ] {0b6fab1f-a018-4795-94e3-ef4c3c5b1c09} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(11.1, 121.1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58028) (comment: 00515_gcd_lcm.sql) (query 32, line 36) (in query: select lcm(11.1, 121.1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000012ace216 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000128999f9 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a174126 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:48:39.620615 [ 9260 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(11.1, 121.1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000012ace216 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000128999f9 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a174126 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:48:39.638532 [ 9260 ] {5c768afd-59a7-4e31-a632-2b6659568354} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(-256.1, 64.1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58028) (comment: 00515_gcd_lcm.sql) (query 33, line 37) (in query: select lcm(-256.1, 64.1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000012ace216 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000128999f9 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a174126 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:48:39.642047 [ 9260 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(-256.1, 64.1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000012ace216 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000128999f9 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a174126 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:48:39.658946 [ 9260 ] {754fa61c-9000-4fc6-b083-f324190eba88} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(1.1, 1.1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58028) (comment: 00515_gcd_lcm.sql) (query 34, line 38) (in query: select lcm(1.1, 1.1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000012ace216 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000128999f9 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a174126 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:48:39.662108 [ 9260 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(1.1, 1.1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000012ace216 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000128999f9 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a174126 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:48:39.679158 [ 9260 ] {8b559743-4be4-4014-ae29-2fcd808347f5} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(4.1, 2.1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58028) (comment: 00515_gcd_lcm.sql) (query 35, line 39) (in query: select lcm(4.1, 2.1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000012ace216 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000128999f9 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a174126 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:48:39.682217 [ 9260 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(4.1, 2.1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000012ace216 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000128999f9 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a174126 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:48:39.704994 [ 9260 ] {2d0aa8c5-739f-463d-b935-c5b05be6f7ec} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(15.1, 49.1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58028) (comment: 00515_gcd_lcm.sql) (query 36, line 40) (in query: select lcm(15.1, 49.1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000012ace216 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000128999f9 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a174126 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:48:39.708889 [ 9260 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(15.1, 49.1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000012ace216 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000128999f9 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a174126 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:48:39.731470 [ 9260 ] {5bb84562-c27a-42df-9221-3eb6db7b7d7c} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(255.1, 254.1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58028) (comment: 00515_gcd_lcm.sql) (query 37, line 41) (in query: select lcm(255.1, 254.1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000012ace216 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000128999f9 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a174126 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:48:39.735335 [ 9260 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(255.1, 254.1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000012ace216 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000128999f9 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a174126 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:48:40.862235 [ 9261 ] {675ee112-ea0c-433c-96f9-d1ad85a5c01e} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONEachRow format file. Error: Code: 652. DB::Exception: Cannot determine type for column 'a' by first 1 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 25.3.3.20286.altinityantalya (altinity build)) To increase the maximum number of rows/bytes to read for structure determination, use setting input_format_max_rows_to_read_for_schema_inference/input_format_max_bytes_to_read_for_schema_inference. You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58180) (comment: 02783_max_bytes_to_read_in_schema_inference.sql) (query 3, line 3) (in query: desc format('JSONEachRow', '{"a" : null}, {"a" : 42}') settings input_format_max_bytes_to_read_for_schema_inference=10;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001a317bad 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:487: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003afd5a28 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003afd97ae 6. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:97: DB::(anonymous namespace)::TableFunctionFormat::getActualTableStructure(std::shared_ptr, bool) const @ 0x00000000266c0a1c 7. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x00000000338721cc 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x000000003386e605 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:48:40.865165 [ 9261 ] {} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONEachRow format file. Error: Code: 652. DB::Exception: Cannot determine type for column 'a' by first 1 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 25.3.3.20286.altinityantalya (altinity build)) To increase the maximum number of rows/bytes to read for structure determination, use setting input_format_max_rows_to_read_for_schema_inference/input_format_max_bytes_to_read_for_schema_inference. You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001a317bad 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:487: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003afd5a28 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003afd97ae 6. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:97: DB::(anonymous namespace)::TableFunctionFormat::getActualTableStructure(std::shared_ptr, bool) const @ 0x00000000266c0a1c 7. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x00000000338721cc 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x000000003386e605 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:48:46.559841 [ 9259 ] {3c5c38bd-5bd4-4de1-9545-62e64d08c1b4} executeQuery: Code: 81. DB::Exception: Database nonexistent does not exist. (UNKNOWN_DATABASE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:41214) (comment: 03319_http_exception_formatting_during_interpretation.sh) (in query: SELECT * FROM nonexistent.nonexistent FORMAT JSONLines), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Interpreters/Context.cpp:5680: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000003174f585 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:161: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x0000000031022964 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035d64c 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4364: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c4340 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 20. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 21. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:48:46.571082 [ 9259 ] {3c5c38bd-5bd4-4de1-9545-62e64d08c1b4} DynamicQueryHandler: Code: 81. DB::Exception: Database nonexistent does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Interpreters/Context.cpp:5680: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000003174f585 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:161: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x0000000031022964 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035d64c 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4364: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c4340 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 20. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 21. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:48:51.440013 [ 2136 ] {224d4438-a05e-4a5b-93a2-6857cae6f9f1} DynamicQueryHandler: Code: 271. DB::Exception: Can't decompress data: header is corrupt with compressed block size 0. (CANNOT_DECOMPRESS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Compression/ICompressionCodec.cpp:128: DB::ICompressionCodec::readCompressedBlockSize(char const*) const @ 0x000000003dd50186 5. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:157: DB::readHeaderAndGetCodecAndSize(char const*, char8_t, std::shared_ptr&, unsigned long&, unsigned long&, bool, bool) @ 0x000000003dbfe9dc 6. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:185: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dbfd818 7. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:12: non-virtual thunk to DB::CompressedReadBuffer::nextImpl() @ 0x000000003dbfcb4d 8. DB::ReadBuffer::next() @ 0x0000000008e83ccf 9. ./build_docker/./src/IO/ReadBuffer.cpp:34: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000001f87aa86 10. DB::ReadBuffer::next() @ 0x0000000008e83ccf 11. ./src/IO/ReadBuffer.h:96: DB::ConcatReadBuffer::nextImpl() @ 0x00000000315a8937 12. DB::ReadBuffer::next() @ 0x0000000008e83ccf 13. ./src/IO/ReadBuffer.h:81: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000337403da 14. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 15. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 16. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:48:52.823780 [ 3514 ] {30739ce1-3b2b-4a9b-b29f-eff23cb8f3c7} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:43328). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43328) (comment: 02479_race_condition_between_insert_and_droppin_mv.sh) (query 1, line 1) (in query: INSERT INTO test_race_condition_landing SELECT number, toString(number), toString(number) from system.numbers limit 44804, 500 settings ignore_materialized_views_with_dropped_target_table=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:1475: DB::TCPHandler::sendProfileEvents(DB::QueryState&) @ 0x000000003adeb88a 7. ./build_docker/./src/Server/TCPHandler.cpp:1490: DB::TCPHandler::runImpl() @ 0x000000003ad8f181 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:48:52.827286 [ 3514 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:43328). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:1475: DB::TCPHandler::sendProfileEvents(DB::QueryState&) @ 0x000000003adeb88a 7. ./build_docker/./src/Server/TCPHandler.cpp:1490: DB::TCPHandler::runImpl() @ 0x000000003ad8f181 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:48:53.470708 [ 2134 ] {23a814ab-d820-4484-8f0a-e0849929461b} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function with ArgMin suffix. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43340) (comment: 02885_arg_min_max_combinator.sql) (query 4, line 4) (in query: select sumArgMin() from numbers(100);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionCombinatorsArgMinArgMax.cpp:194: DB::(anonymous namespace)::CombinatorArgMinArgMax::transformArguments(std::vector, std::allocator>> const&) const @ 0x000000002630b7cd 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:250: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002d00969b 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303855f9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 29. ? @ 0x00007f5206343ac3 30. ? @ 0x00007f52063d5850 2025.06.13 08:48:53.475178 [ 2134 ] {} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function with ArgMin suffix. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionCombinatorsArgMinArgMax.cpp:194: DB::(anonymous namespace)::CombinatorArgMinArgMax::transformArguments(std::vector, std::allocator>> const&) const @ 0x000000002630b7cd 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:250: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002d00969b 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303855f9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 29. ? @ 0x00007f5206343ac3 30. ? @ 0x00007f52063d5850 2025.06.13 08:48:53.753289 [ 2134 ] {01ab12ee-f163-4cd1-8866-7a6a4ee05367} executeQuery: Code: 42. DB::Exception: Aggregate function sum requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43340) (comment: 02885_arg_min_max_combinator.sql) (query 5, line 5) (in query: select sumArgMin(number) from numbers(100);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./src/AggregateFunctions/FactoryHelpers.h:26: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionSum(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000023d57075 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000203d4b63 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d009bfb 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002d009778 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303855f9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:48:53.756910 [ 2134 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function sum requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./src/AggregateFunctions/FactoryHelpers.h:26: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionSum(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000023d57075 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000203d4b63 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d009bfb 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002d009778 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303855f9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:48:54.021338 [ 2134 ] {ee913fac-6ca0-4e43-816e-c8142e5f5870} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(sum, UInt64) for combinator sumArgMin because the values of that data type are not comparable. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43340) (comment: 02885_arg_min_max_combinator.sql) (query 6, line 6) (in query: -- Try passing a non comparable type, for example an AggregationState select sumArgMin(number, unhex('0000000000000000')::AggregateFunction(sum, UInt64)) from numbers(100);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionCombinatorsArgMinArgMax.cpp:61: DB::(anonymous namespace)::CombinatorArgMinArgMax::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x000000002630c80e 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002d00a044 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303855f9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 29. ? @ 0x00007f5206343ac3 30. ? @ 0x00007f52063d5850 2025.06.13 08:48:54.025001 [ 2134 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(sum, UInt64) for combinator sumArgMin because the values of that data type are not comparable. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionCombinatorsArgMinArgMax.cpp:61: DB::(anonymous namespace)::CombinatorArgMinArgMax::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x000000002630c80e 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002d00a044 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303855f9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 29. ? @ 0x00007f5206343ac3 30. ? @ 0x00007f52063d5850 2025.06.13 08:49:00.569444 [ 9220 ] {ebf95424-1037-4b50-ae91-22e85ce0a0ca} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35852) (comment: 02479_race_condition_between_insert_and_droppin_mv.sh) (query 1, line 1) (in query: INSERT INTO test_race_condition_landing SELECT number, toString(number), toString(number) from system.numbers limit 483, 500 settings ignore_materialized_views_with_dropped_target_table=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003adff16b 3. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003ade861b 4. ./build_docker/./src/Server/TCPHandler.cpp:692: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003adfc8ee 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003b0aa8fc 6. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 2025.06.13 08:49:00.596526 [ 9220 ] {ebf95424-1037-4b50-ae91-22e85ce0a0ca} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:35852). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2557: DB::TCPHandler::sendException(DB::Exception const&, bool) @ 0x000000003adb5f67 7. ./build_docker/./src/Server/TCPHandler.cpp:825: DB::TCPHandler::runImpl() @ 0x000000003ad8f542 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:00.600699 [ 9220 ] {} TCPHandler: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003adff16b 3. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003ade861b 4. ./build_docker/./src/Server/TCPHandler.cpp:692: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003adfc8ee 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003b0aa8fc 6. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 2025.06.13 08:49:00.722279 [ 9234 ] {e51897ff-eaf9-4018-9f51-af16840986f0} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:35854, local: [::1]:9000). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35854) (comment: 02479_race_condition_between_insert_and_droppin_mv.sh) (query 1, line 1) (in query: INSERT INTO test_race_condition_landing SELECT number, toString(number), toString(number) from system.numbers limit 401, 500 settings ignore_materialized_views_with_dropped_target_table=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fbc2c6f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fbc3c01 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9b2eba 6. DB::ReadBuffer::next() @ 0x0000000008e83ccf 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003ade730e 8. ./build_docker/./src/Server/TCPHandler.cpp:692: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003adfc8ee 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003b0aa8fc 10. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 08:49:00.735926 [ 9234 ] {e51897ff-eaf9-4018-9f51-af16840986f0} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:35854). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2531: DB::TCPHandler::sendLogData(DB::QueryState&, DB::Block const&) @ 0x000000003adf5ea1 7. ./build_docker/./src/Server/TCPHandler.cpp:2619: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x000000003adbfa58 8. ./build_docker/./src/Server/TCPHandler.cpp:820: DB::TCPHandler::runImpl() @ 0x000000003ad8f4a9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:00.740429 [ 9234 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:35854, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fbc2c6f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fbc3c01 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9b2eba 6. DB::ReadBuffer::next() @ 0x0000000008e83ccf 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003ade730e 8. ./build_docker/./src/Server/TCPHandler.cpp:692: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003adfc8ee 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003b0aa8fc 10. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 08:49:00.896705 [ 4332 ] {acba2c2a-ef68-4ad4-a7bc-0826fb65123a} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35860) (comment: 02479_race_condition_between_insert_and_droppin_mv.sh) (query 1, line 1) (in query: INSERT INTO test_race_condition_landing SELECT number, toString(number), toString(number) from system.numbers limit 485, 500 settings ignore_materialized_views_with_dropped_target_table=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003adff16b 3. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003ade861b 4. ./build_docker/./src/Server/TCPHandler.cpp:692: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003adfc8ee 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003b0aa8fc 6. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 2025.06.13 08:49:00.911677 [ 4332 ] {acba2c2a-ef68-4ad4-a7bc-0826fb65123a} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:35860). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2557: DB::TCPHandler::sendException(DB::Exception const&, bool) @ 0x000000003adb5f67 7. ./build_docker/./src/Server/TCPHandler.cpp:825: DB::TCPHandler::runImpl() @ 0x000000003ad8f542 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:00.915449 [ 4332 ] {} TCPHandler: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003adff16b 3. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003ade861b 4. ./build_docker/./src/Server/TCPHandler.cpp:692: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003adfc8ee 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003b0aa8fc 6. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 2025.06.13 08:49:05.353757 [ 9249 ] {22ae9811-b861-41a2-9f68-98326a455c84} executeQuery: Code: 59. DB::Exception: Invalid type for filter in WHERE: Tuple(a UInt64, b UInt64). In query SELECT x FROM tab ARRAY JOIN arr PREWHERE x != 0 WHERE arr. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37438) (comment: 01674_where_prewhere_array_crash.sql) (query 3, line 3) (in query: select x from tab array join arr prewhere x != 0 where arr;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000002ea6aad7 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x000000003045851f 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:74: DB::validateFilters(std::shared_ptr const&) @ 0x00000000304578e3 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5758: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000030310dd8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:49:05.357235 [ 9249 ] {} TCPHandler: Code: 59. DB::Exception: Invalid type for filter in WHERE: Tuple(a UInt64, b UInt64). In query SELECT x FROM tab ARRAY JOIN arr PREWHERE x != 0 WHERE arr. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000002ea6aad7 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x000000003045851f 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:74: DB::validateFilters(std::shared_ptr const&) @ 0x00000000304578e3 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5758: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000030310dd8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:49:05.534333 [ 9249 ] {10ec2ad9-3563-4c8f-9acb-d4647fd3209e} executeQuery: Code: 59. DB::Exception: Invalid type for filter in PREWHERE: Tuple(a UInt64, b UInt64). In query SELECT x FROM tab ARRAY JOIN arr PREWHERE arr WHERE x != 0. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37438) (comment: 01674_where_prewhere_array_crash.sql) (query 4, line 4) (in query: select x from tab array join arr prewhere arr where x != 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000002ea6aad7 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x000000003045851f 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:64: DB::validateFilters(std::shared_ptr const&) @ 0x0000000030457749 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5758: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000030310dd8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:49:05.537673 [ 9249 ] {} TCPHandler: Code: 59. DB::Exception: Invalid type for filter in PREWHERE: Tuple(a UInt64, b UInt64). In query SELECT x FROM tab ARRAY JOIN arr PREWHERE arr WHERE x != 0. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000002ea6aad7 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x000000003045851f 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:64: DB::validateFilters(std::shared_ptr const&) @ 0x0000000030457749 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5758: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000030310dd8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:49:07.328524 [ 9231 ] {a80fa9c0-c501-43f7-b90b-259ef1acd6be} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:35004) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: SELECT `__table1`.`number` AS `number` FROM numbers(20) AS `__table1` LIMIT _CAST(8, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003adff16b 3. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003ade861b 4. ./build_docker/./src/Server/TCPHandler.cpp:1241: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe46c 5. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 08:49:07.333020 [ 9231 ] {a80fa9c0-c501-43f7-b90b-259ef1acd6be} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:35004). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2531: DB::TCPHandler::sendLogData(DB::QueryState&, DB::Block const&) @ 0x000000003adf5ea1 7. ./build_docker/./src/Server/TCPHandler.cpp:2619: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x000000003adbfa58 8. ./build_docker/./src/Server/TCPHandler.cpp:820: DB::TCPHandler::runImpl() @ 0x000000003ad8f4a9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:07.336979 [ 9249 ] {40530279-1978-4686-92f7-49b7905a2fbe} executeQuery: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37456) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: select number from remote('127.0.0.{2,3}', numbers(20)) limit 8 settings max_block_size = 2, unknown_packet_in_send_data=4, sleep_in_send_data_ms=100, async_socket_for_remote=1 format Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a1f836d 4. ./build_docker/./src/Client/Connection.cpp:1322: DB::Connection::receivePacket() @ 0x000000003a99c000 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aa95398 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 2025.06.13 08:49:07.338706 [ 9231 ] {} TCPHandler: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003adff16b 3. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003ade861b 4. ./build_docker/./src/Server/TCPHandler.cpp:1241: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe46c 5. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 08:49:07.343623 [ 404 ] {023d500a-2a9a-4f21-9a35-c0f8e314bbf7} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:36232). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc8fc3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2569: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000003adc01f6 7. ./build_docker/./src/Server/TCPHandler.cpp:823: DB::TCPHandler::runImpl() @ 0x000000003ad8f4fc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:07.350580 [ 9249 ] {} TCPHandler: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a1f836d 4. ./build_docker/./src/Client/Connection.cpp:1322: DB::Connection::receivePacket() @ 0x000000003a99c000 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aa95398 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:49:08.661095 [ 9231 ] {2441cec2-30e1-4fea-b4d5-1a8707bdc6d0} executeQuery: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37488) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: select number from remote('127.0.0.{2,3}', numbers(20)) limit 8 settings max_block_size = 2, unknown_packet_in_send_data=4, sleep_in_send_data_ms=100, async_socket_for_remote=1 format Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a1f836d 4. ./build_docker/./src/Client/Connection.cpp:1322: DB::Connection::receivePacket() @ 0x000000003a99c000 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aa95398 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 2025.06.13 08:49:08.673048 [ 9231 ] {} TCPHandler: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a1f836d 4. ./build_docker/./src/Client/Connection.cpp:1322: DB::Connection::receivePacket() @ 0x000000003a99c000 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aa95398 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:49:08.687355 [ 404 ] {2585827c-16bf-45c8-b690-4ff5ce4c6ca8} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'idontexist' in scope SELECT 1 FROM idontexist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37502) (comment: 03326_client_ignore_error_multiquery.sh) (query 1, line 1) (in query: SELECT 1 FROM idontexist;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:49:08.691950 [ 404 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'idontexist' in scope SELECT 1 FROM idontexist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:49:08.752856 [ 9263 ] {5df70dff-c901-41db-bdd8-9fe41f164db5} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:35006) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: SELECT `__table1`.`number` AS `number` FROM numbers(20) AS `__table1` LIMIT _CAST(8, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003adff16b 3. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003ade861b 4. ./build_docker/./src/Server/TCPHandler.cpp:1241: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe46c 5. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 08:49:08.758366 [ 9263 ] {5df70dff-c901-41db-bdd8-9fe41f164db5} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:35006). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2531: DB::TCPHandler::sendLogData(DB::QueryState&, DB::Block const&) @ 0x000000003adf5ea1 7. ./build_docker/./src/Server/TCPHandler.cpp:2619: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x000000003adbfa58 8. ./build_docker/./src/Server/TCPHandler.cpp:820: DB::TCPHandler::runImpl() @ 0x000000003ad8f4a9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:08.760091 [ 2136 ] {832f650d-e8bc-4275-b2c5-b7055de96dd7} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:36248). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc8fc3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe68d 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:08.761786 [ 2136 ] {832f650d-e8bc-4275-b2c5-b7055de96dd7} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:36248). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:36248) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: SELECT `__table1`.`number` AS `number` FROM numbers(20) AS `__table1` LIMIT _CAST(8, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc8fc3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe68d 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:49:08.764590 [ 9263 ] {} TCPHandler: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003adff16b 3. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003ade861b 4. ./build_docker/./src/Server/TCPHandler.cpp:1241: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe46c 5. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 08:49:08.768483 [ 2136 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:36248). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc8fc3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe68d 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:49:09.900196 [ 9260 ] {c9dc2e2f-ac39-4163-95b1-468c02eb3f43} executeQuery: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.3:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37512) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: select number from remote('127.0.0.{2,3}', numbers(20)) limit 8 settings max_block_size = 2, unknown_packet_in_send_data=4, sleep_in_send_data_ms=100, async_socket_for_remote=1 format Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a1f836d 4. ./build_docker/./src/Client/Connection.cpp:1322: DB::Connection::receivePacket() @ 0x000000003a99c000 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aa95398 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 2025.06.13 08:49:09.914014 [ 2141 ] {7e58700f-2048-4ba3-9986-475a854fe6a3} executeQuery: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT caseWithExpr(arrayReduce(NULL, []), []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37530) (comment: 02732_transform_fuzz.sql) (query 1, line 1) (in query: SELECT caseWithExpr(arrayReduce(NULL, []), []);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x000000001e2aeef9 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7eb0 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 08:49:09.917939 [ 2141 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT caseWithExpr(arrayReduce(NULL, []), []). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x000000001e2aeef9 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7eb0 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 08:49:09.927118 [ 9260 ] {} TCPHandler: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.3:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a1f836d 4. ./build_docker/./src/Client/Connection.cpp:1322: DB::Connection::receivePacket() @ 0x000000003a99c000 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aa95398 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:49:09.997304 [ 2133 ] {5da6ed2e-f1e0-4107-bfda-b805a5ad0ffe} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:36260) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: SELECT `__table1`.`number` AS `number` FROM numbers(20) AS `__table1` LIMIT _CAST(8, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003adff16b 3. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003ade861b 4. ./build_docker/./src/Server/TCPHandler.cpp:1241: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe46c 5. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 08:49:09.999936 [ 2134 ] {eeb5ebdb-ba3e-4da0-8445-aba060096236} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:35014). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc8fc3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe68d 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:10.001549 [ 2134 ] {eeb5ebdb-ba3e-4da0-8445-aba060096236} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:35014). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:35014) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: SELECT `__table1`.`number` AS `number` FROM numbers(20) AS `__table1` LIMIT _CAST(8, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc8fc3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe68d 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:49:10.002464 [ 2133 ] {5da6ed2e-f1e0-4107-bfda-b805a5ad0ffe} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:36260). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2531: DB::TCPHandler::sendLogData(DB::QueryState&, DB::Block const&) @ 0x000000003adf5ea1 7. ./build_docker/./src/Server/TCPHandler.cpp:2619: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x000000003adbfa58 8. ./build_docker/./src/Server/TCPHandler.cpp:820: DB::TCPHandler::runImpl() @ 0x000000003ad8f4a9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:10.008490 [ 2134 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:35014). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc8fc3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe68d 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:49:10.008507 [ 2133 ] {} TCPHandler: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003adff16b 3. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003ade861b 4. ./build_docker/./src/Server/TCPHandler.cpp:1241: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe46c 5. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 08:49:11.201156 [ 2136 ] {38ecd43c-83c0-4ec9-b5de-ba4a8ca39442} executeQuery: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37562) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: select number from remote('127.0.0.{2,3}', numbers(20)) limit 8 settings max_block_size = 2, unknown_packet_in_send_data=4, sleep_in_send_data_ms=100, async_socket_for_remote=1 format Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a1f836d 4. ./build_docker/./src/Client/Connection.cpp:1322: DB::Connection::receivePacket() @ 0x000000003a99c000 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aa95398 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 2025.06.13 08:49:11.212332 [ 2136 ] {} TCPHandler: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a1f836d 4. ./build_docker/./src/Client/Connection.cpp:1322: DB::Connection::receivePacket() @ 0x000000003a99c000 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aa95398 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:49:11.264299 [ 9262 ] {eb81b70b-96e1-4535-80a5-bc982fd40ba3} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:35020) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: SELECT `__table1`.`number` AS `number` FROM numbers(20) AS `__table1` LIMIT _CAST(8, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003adff16b 3. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003ade861b 4. ./build_docker/./src/Server/TCPHandler.cpp:1241: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe46c 5. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 08:49:11.269997 [ 9262 ] {eb81b70b-96e1-4535-80a5-bc982fd40ba3} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:35020). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2531: DB::TCPHandler::sendLogData(DB::QueryState&, DB::Block const&) @ 0x000000003adf5ea1 7. ./build_docker/./src/Server/TCPHandler.cpp:2619: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x000000003adbfa58 8. ./build_docker/./src/Server/TCPHandler.cpp:820: DB::TCPHandler::runImpl() @ 0x000000003ad8f4a9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:11.276704 [ 9262 ] {} TCPHandler: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003adff16b 3. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003ade861b 4. ./build_docker/./src/Server/TCPHandler.cpp:1241: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe46c 5. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 08:49:11.291655 [ 9229 ] {1ab60c4e-e0fe-4746-9afb-bbf67af18562} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:36272). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc8fc3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe68d 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:11.293579 [ 9229 ] {1ab60c4e-e0fe-4746-9afb-bbf67af18562} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:36272). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:36272) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: SELECT `__table1`.`number` AS `number` FROM numbers(20) AS `__table1` LIMIT _CAST(8, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc8fc3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe68d 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:49:11.299779 [ 9229 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:36272). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc8fc3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe68d 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:49:11.415479 [ 4332 ] {4f2ab0af-7c64-4073-9aa6-5c765d639523} executeQuery: Code: 691. DB::Exception: Unknown element 'goodbye' for enum. (UNKNOWN_ELEMENT_OF_ENUM) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37578) (comment: 02958_transform_enum.sql) (query 2, line 2) (in query: WITH arrayJoin(['Hello', 'world'])::Enum('Hello', 'world') AS x SELECT x, transform(x, ['Hello', 'world', 'goodbye'], [123, 456], 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000d28002d 4. ./build_docker/./src/DataTypes/EnumValues.cpp:72: DB::EnumValues<_BitInt(8)>::getValue(StringRef) const @ 0x000000002f3d8d8c 5. std::function::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createStringToEnumWrapper>() const::'lambda'(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long)::operator()(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long) const @ 0x000000002c744bdd 6. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createStringToEnumWrapper>() const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c744464 7. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff69df 12. ./build_docker/./src/Interpreters/castColumn.cpp:39: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000336772b9 13. ./build_docker/./src/Interpreters/castColumn.cpp:44: DB::castColumn(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000336761b9 14. void std::__call_once_proxy[abi:ne190107]> const&, std::shared_ptr const&, unsigned long) const::'lambda'()&&>>(void*) @ 0x000000001aca6ddf 15. ./build_docker/./contrib/llvm-project/libcxx/src/call_once.cpp:57: std::__call_once(unsigned long volatile&, void*, void (*)(void*)) @ 0x000000004974ce08 16. DB::(anonymous namespace)::FunctionTransform::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ac21bf9 17. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 18. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 22. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301087b6 23. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000030104ffd 24. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003ba0ea77 25. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003bfff312 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032b1845f 27. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x0000000032b01504 28. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 2025.06.13 08:49:11.418979 [ 4332 ] {} TCPHandler: Code: 691. DB::Exception: Unknown element 'goodbye' for enum. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000d28002d 4. ./build_docker/./src/DataTypes/EnumValues.cpp:72: DB::EnumValues<_BitInt(8)>::getValue(StringRef) const @ 0x000000002f3d8d8c 5. std::function::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createStringToEnumWrapper>() const::'lambda'(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long)::operator()(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long) const @ 0x000000002c744bdd 6. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createStringToEnumWrapper>() const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c744464 7. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff69df 12. ./build_docker/./src/Interpreters/castColumn.cpp:39: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000336772b9 13. ./build_docker/./src/Interpreters/castColumn.cpp:44: DB::castColumn(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000336761b9 14. void std::__call_once_proxy[abi:ne190107]> const&, std::shared_ptr const&, unsigned long) const::'lambda'()&&>>(void*) @ 0x000000001aca6ddf 15. ./build_docker/./contrib/llvm-project/libcxx/src/call_once.cpp:57: std::__call_once(unsigned long volatile&, void*, void (*)(void*)) @ 0x000000004974ce08 16. DB::(anonymous namespace)::FunctionTransform::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ac21bf9 17. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 18. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 22. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301087b6 23. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000030104ffd 24. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003ba0ea77 25. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003bfff312 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032b1845f 27. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x0000000032b01504 28. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 2025.06.13 08:49:12.582757 [ 2136 ] {3d88af30-a5fb-4c0e-b295-a5bb62904aec} executeQuery: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37642) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: select number from remote('127.0.0.{2,3}', numbers(20)) limit 8 settings max_block_size = 2, unknown_packet_in_send_data=4, sleep_in_send_data_ms=100, async_socket_for_remote=1 format Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a1f836d 4. ./build_docker/./src/Client/Connection.cpp:1322: DB::Connection::receivePacket() @ 0x000000003a99c000 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aa95398 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 2025.06.13 08:49:12.598927 [ 2136 ] {} TCPHandler: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a1f836d 4. ./build_docker/./src/Client/Connection.cpp:1322: DB::Connection::receivePacket() @ 0x000000003a99c000 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aa95398 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:49:12.661852 [ 9229 ] {43dda6dd-e20f-4d86-8c08-c3c93b654b52} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:35032) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: SELECT `__table1`.`number` AS `number` FROM numbers(20) AS `__table1` LIMIT _CAST(8, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003adff16b 3. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003ade861b 4. ./build_docker/./src/Server/TCPHandler.cpp:1241: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe46c 5. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 08:49:12.666298 [ 9229 ] {43dda6dd-e20f-4d86-8c08-c3c93b654b52} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:35032). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2531: DB::TCPHandler::sendLogData(DB::QueryState&, DB::Block const&) @ 0x000000003adf5ea1 7. ./build_docker/./src/Server/TCPHandler.cpp:2619: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x000000003adbfa58 8. ./build_docker/./src/Server/TCPHandler.cpp:820: DB::TCPHandler::runImpl() @ 0x000000003ad8f4a9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:12.672316 [ 9229 ] {} TCPHandler: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003adff16b 3. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003ade861b 4. ./build_docker/./src/Server/TCPHandler.cpp:1241: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe46c 5. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 08:49:12.675706 [ 9234 ] {31ed1f9c-6842-4d10-ae46-f6f93620a218} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:36288). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc8fc3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe68d 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:12.678299 [ 9234 ] {31ed1f9c-6842-4d10-ae46-f6f93620a218} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:36288). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:36288) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: SELECT `__table1`.`number` AS `number` FROM numbers(20) AS `__table1` LIMIT _CAST(8, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc8fc3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe68d 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:49:12.687006 [ 9234 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:36288). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc8fc3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe68d 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:49:14.027431 [ 9224 ] {d3ac9f85-8c32-4032-b2ad-9059765dd581} executeQuery: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48830) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: select number from remote('127.0.0.{2,3}', numbers(20)) limit 8 settings max_block_size = 2, unknown_packet_in_send_data=4, sleep_in_send_data_ms=100, async_socket_for_remote=1 format Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a1f836d 4. ./build_docker/./src/Client/Connection.cpp:1322: DB::Connection::receivePacket() @ 0x000000003a99c000 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aa95398 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 2025.06.13 08:49:14.042588 [ 9224 ] {} TCPHandler: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a1f836d 4. ./build_docker/./src/Client/Connection.cpp:1322: DB::Connection::receivePacket() @ 0x000000003a99c000 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aa95398 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:49:14.110424 [ 3992 ] {3289dc9f-6d68-4ce7-9bbc-8901f78c4356} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:44830) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: SELECT `__table1`.`number` AS `number` FROM numbers(20) AS `__table1` LIMIT _CAST(8, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003adff16b 3. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003ade861b 4. ./build_docker/./src/Server/TCPHandler.cpp:1241: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe46c 5. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 08:49:14.116712 [ 3992 ] {3289dc9f-6d68-4ce7-9bbc-8901f78c4356} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:44830). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2531: DB::TCPHandler::sendLogData(DB::QueryState&, DB::Block const&) @ 0x000000003adf5ea1 7. ./build_docker/./src/Server/TCPHandler.cpp:2619: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x000000003adbfa58 8. ./build_docker/./src/Server/TCPHandler.cpp:820: DB::TCPHandler::runImpl() @ 0x000000003ad8f4a9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:14.121364 [ 3992 ] {} TCPHandler: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003adff16b 3. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003ade861b 4. ./build_docker/./src/Server/TCPHandler.cpp:1241: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe46c 5. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 08:49:14.126048 [ 3255 ] {76c0686a-93af-4096-8420-5a68b1fa8954} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:40038). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc8fc3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe68d 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:14.129210 [ 3255 ] {76c0686a-93af-4096-8420-5a68b1fa8954} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:40038). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:40038) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: SELECT `__table1`.`number` AS `number` FROM numbers(20) AS `__table1` LIMIT _CAST(8, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc8fc3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe68d 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:49:14.137209 [ 3255 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:40038). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc8fc3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe68d 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:49:14.182178 [ 9215 ] {3903f272-1a6f-4b96-8a2c-8dd399e98ccb} executeQuery: Code: 43. DB::Exception: Second argument of function fuzzBits must be constant float: In scope SELECT fuzzBits(toString('string'), 1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48872) (comment: 01284_fuzz_bits.sql) (query 1, line 1) (in query: SELECT fuzzBits(toString('string'), 1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionFuzzBits::getReturnTypeImpl(std::vector> const&) const @ 0x000000000edc8d46 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:49:14.185346 [ 9215 ] {} TCPHandler: Code: 43. DB::Exception: Second argument of function fuzzBits must be constant float: In scope SELECT fuzzBits(toString('string'), 1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionFuzzBits::getReturnTypeImpl(std::vector> const&) const @ 0x000000000edc8d46 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:49:14.445319 [ 9215 ] {6b67cf89-0da1-4f76-a43d-0a37969c98f7} executeQuery: Code: 69. DB::Exception: Second argument of function fuzzBits must be from `0.0` to `1.0`: In scope SELECT fuzzBits('string', -1.). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48872) (comment: 01284_fuzz_bits.sql) (query 2, line 2) (in query: SELECT fuzzBits('string', -1.0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionFuzzBits::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000edc7e10 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:49:14.448772 [ 9215 ] {} TCPHandler: Code: 69. DB::Exception: Second argument of function fuzzBits must be from `0.0` to `1.0`: In scope SELECT fuzzBits('string', -1.). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionFuzzBits::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000edc7e10 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:49:15.335706 [ 9224 ] {100adbfc-035c-4326-b435-536a3256ba62} executeQuery: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48912) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: select number from remote('127.0.0.{2,3}', numbers(20)) limit 8 settings max_block_size = 2, unknown_packet_in_send_data=4, sleep_in_send_data_ms=100, async_socket_for_remote=1 format Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a1f836d 4. ./build_docker/./src/Client/Connection.cpp:1322: DB::Connection::receivePacket() @ 0x000000003a99c000 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aa95398 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 2025.06.13 08:49:15.351817 [ 9224 ] {} TCPHandler: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a1f836d 4. ./build_docker/./src/Client/Connection.cpp:1322: DB::Connection::receivePacket() @ 0x000000003a99c000 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aa95398 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:49:15.409840 [ 9235 ] {2dfc1ef9-d61b-47eb-bdfc-268b6e64078c} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:44842) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: SELECT `__table1`.`number` AS `number` FROM numbers(20) AS `__table1` LIMIT _CAST(8, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003adff16b 3. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003ade861b 4. ./build_docker/./src/Server/TCPHandler.cpp:1241: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe46c 5. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 08:49:15.416172 [ 9235 ] {2dfc1ef9-d61b-47eb-bdfc-268b6e64078c} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:44842). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2531: DB::TCPHandler::sendLogData(DB::QueryState&, DB::Block const&) @ 0x000000003adf5ea1 7. ./build_docker/./src/Server/TCPHandler.cpp:2619: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x000000003adbfa58 8. ./build_docker/./src/Server/TCPHandler.cpp:820: DB::TCPHandler::runImpl() @ 0x000000003ad8f4a9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:15.422625 [ 9235 ] {} TCPHandler: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003adff16b 3. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003ade861b 4. ./build_docker/./src/Server/TCPHandler.cpp:1241: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe46c 5. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 08:49:15.434229 [ 2142 ] {75811f13-0f05-4cf6-bf4f-b27951fdc3f1} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:40048). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc8fc3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe68d 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:15.436818 [ 2142 ] {75811f13-0f05-4cf6-bf4f-b27951fdc3f1} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:40048). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:40048) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: SELECT `__table1`.`number` AS `number` FROM numbers(20) AS `__table1` LIMIT _CAST(8, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc8fc3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe68d 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:49:15.446825 [ 2142 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:40048). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc8fc3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe68d 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:49:15.448574 [ 9237 ] {5ad370c9-2966-47eb-913d-6ed82120b753} executeQuery: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48934) (query 1, line 1) (in query: select _path,_file from file('nonexist.txt', 'CSV', 'val1 char')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/StorageFile.cpp:1630: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003841b9f8 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032b6f004 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032b5101c 7. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x0000000032afc62e 8. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:49:15.454227 [ 9237 ] {} TCPHandler: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/StorageFile.cpp:1630: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003841b9f8 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032b6f004 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032b5101c 7. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x0000000032afc62e 8. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:49:17.316856 [ 15871 ] {da75fde8-8ab7-4b07-973a-620fe9d64510} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 76.30 MiB (attempt to allocate chunk of 76.30 MiB bytes), maximum: 15.26 MiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49324) (comment: 01109_inflating_cross_join.sql) (query 3, line 4) (in query: SELECT count(*) FROM numbers(10000) n1 CROSS JOIN numbers(1000) n2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f53d7c4 8. ./src/Common/PODArray.h:152: DB::ColumnVector::reserve(unsigned long) @ 0x0000000037a1a86e 9. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:880: DB::HashJoin::joinBlockImplCross(DB::Block&, std::shared_ptr&) const @ 0x0000000033ae0e3c 10. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1050: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000033ae91eb 11. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003ba20ce4 12. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x000000003c0798c8 13. ./build_docker/./src/Processors/QueryPlan/IQueryPlanStep.cpp:26: DB::IQueryPlanStep::updateInputHeaders(std::vector>) @ 0x000000003c043a57 14. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x000000003c072fc1 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032b91e05 16. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1628: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032b55d9f 17. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x0000000032afc62e 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 29. ? @ 0x00007f5206343ac3 30. ? @ 0x00007f52063d5850 2025.06.13 08:49:17.331380 [ 15871 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 76.30 MiB (attempt to allocate chunk of 76.30 MiB bytes), maximum: 15.26 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f53d7c4 8. ./src/Common/PODArray.h:152: DB::ColumnVector::reserve(unsigned long) @ 0x0000000037a1a86e 9. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:880: DB::HashJoin::joinBlockImplCross(DB::Block&, std::shared_ptr&) const @ 0x0000000033ae0e3c 10. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1050: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000033ae91eb 11. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003ba20ce4 12. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x000000003c0798c8 13. ./build_docker/./src/Processors/QueryPlan/IQueryPlanStep.cpp:26: DB::IQueryPlanStep::updateInputHeaders(std::vector>) @ 0x000000003c043a57 14. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x000000003c072fc1 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032b91e05 16. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1628: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032b55d9f 17. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x0000000032afc62e 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 29. ? @ 0x00007f5206343ac3 30. ? @ 0x00007f52063d5850 2025.06.13 08:49:17.380333 [ 9259 ] {68bddd3f-9747-4c94-a933-4dfe722066b5} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:44856) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: SELECT `__table1`.`number` AS `number` FROM numbers(20) AS `__table1` LIMIT _CAST(8, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003adff16b 3. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003ade861b 4. ./build_docker/./src/Server/TCPHandler.cpp:1241: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe46c 5. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 08:49:17.389872 [ 9259 ] {68bddd3f-9747-4c94-a933-4dfe722066b5} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:44856). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2531: DB::TCPHandler::sendLogData(DB::QueryState&, DB::Block const&) @ 0x000000003adf5ea1 7. ./build_docker/./src/Server/TCPHandler.cpp:2619: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x000000003adbfa58 8. ./build_docker/./src/Server/TCPHandler.cpp:820: DB::TCPHandler::runImpl() @ 0x000000003ad8f4a9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:17.394712 [ 9259 ] {} TCPHandler: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003adff16b 3. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003ade861b 4. ./build_docker/./src/Server/TCPHandler.cpp:1241: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe46c 5. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 08:49:17.418149 [ 15843 ] {30e0f1b6-ec03-455b-8274-65c53fde789e} executeQuery: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49256) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: select number from remote('127.0.0.{2,3}', numbers(20)) limit 8 settings max_block_size = 2, unknown_packet_in_send_data=4, sleep_in_send_data_ms=100, async_socket_for_remote=1 format Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a1f836d 4. ./build_docker/./src/Client/Connection.cpp:1322: DB::Connection::receivePacket() @ 0x000000003a99c000 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aa95398 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 2025.06.13 08:49:17.456488 [ 15843 ] {} TCPHandler: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a1f836d 4. ./build_docker/./src/Client/Connection.cpp:1322: DB::Connection::receivePacket() @ 0x000000003a99c000 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aa95398 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:49:17.482398 [ 15841 ] {b6e8675e-40b9-4c4f-8b18-903000cb3299} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:40054). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2569: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000003adc01f6 7. ./build_docker/./src/Server/TCPHandler.cpp:823: DB::TCPHandler::runImpl() @ 0x000000003ad8f4fc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:19.282663 [ 15841 ] {fd19eecc-14be-42cb-a66c-2c3132434ad3} executeQuery: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.3:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49340) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: select number from remote('127.0.0.{2,3}', numbers(20)) limit 8 settings max_block_size = 2, unknown_packet_in_send_data=4, sleep_in_send_data_ms=100, async_socket_for_remote=1 format Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a1f836d 4. ./build_docker/./src/Client/Connection.cpp:1322: DB::Connection::receivePacket() @ 0x000000003a99c000 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aa95398 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 2025.06.13 08:49:19.326903 [ 15841 ] {} TCPHandler: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.3:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a1f836d 4. ./build_docker/./src/Client/Connection.cpp:1322: DB::Connection::receivePacket() @ 0x000000003a99c000 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aa95398 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:49:19.357462 [ 15843 ] {b391c5db-22b6-4960-918e-eb210566df49} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:40058) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: SELECT `__table1`.`number` AS `number` FROM numbers(20) AS `__table1` LIMIT _CAST(8, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003adff16b 3. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003ade861b 4. ./build_docker/./src/Server/TCPHandler.cpp:1241: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe46c 5. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 08:49:19.378558 [ 15843 ] {b391c5db-22b6-4960-918e-eb210566df49} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:40058). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2531: DB::TCPHandler::sendLogData(DB::QueryState&, DB::Block const&) @ 0x000000003adf5ea1 7. ./build_docker/./src/Server/TCPHandler.cpp:2619: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x000000003adbfa58 8. ./build_docker/./src/Server/TCPHandler.cpp:820: DB::TCPHandler::runImpl() @ 0x000000003ad8f4a9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:19.382574 [ 15860 ] {c7569693-782b-4ac3-854c-f6b791cbb4a1} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:44858). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2569: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000003adc01f6 7. ./build_docker/./src/Server/TCPHandler.cpp:823: DB::TCPHandler::runImpl() @ 0x000000003ad8f4fc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:19.401444 [ 15843 ] {} TCPHandler: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003adff16b 3. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003ade861b 4. ./build_docker/./src/Server/TCPHandler.cpp:1241: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe46c 5. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 08:49:21.544069 [ 15875 ] {bb3cb53d-82d6-4e6e-83d2-da2d5b1afce5} executeQuery: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49412) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: select number from remote('127.0.0.{2,3}', numbers(20)) limit 8 settings max_block_size = 2, unknown_packet_in_send_data=4, sleep_in_send_data_ms=100, async_socket_for_remote=1 format Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a1f836d 4. ./build_docker/./src/Client/Connection.cpp:1322: DB::Connection::receivePacket() @ 0x000000003a99c000 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aa95398 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 2025.06.13 08:49:21.587923 [ 15875 ] {} TCPHandler: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a1f836d 4. ./build_docker/./src/Client/Connection.cpp:1322: DB::Connection::receivePacket() @ 0x000000003a99c000 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aa95398 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:49:21.614013 [ 15845 ] {89865afa-6be3-4171-ab98-142a84f364aa} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:44868) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: SELECT `__table1`.`number` AS `number` FROM numbers(20) AS `__table1` LIMIT _CAST(8, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003adff16b 3. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003ade861b 4. ./build_docker/./src/Server/TCPHandler.cpp:1241: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe46c 5. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 08:49:21.634772 [ 15845 ] {89865afa-6be3-4171-ab98-142a84f364aa} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:44868). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2531: DB::TCPHandler::sendLogData(DB::QueryState&, DB::Block const&) @ 0x000000003adf5ea1 7. ./build_docker/./src/Server/TCPHandler.cpp:2619: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x000000003adbfa58 8. ./build_docker/./src/Server/TCPHandler.cpp:820: DB::TCPHandler::runImpl() @ 0x000000003ad8f4a9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:21.642569 [ 15862 ] {1a6fb1db-f989-4c95-a50b-f558d01318ce} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:40072). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc8fc3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe68d 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:21.649225 [ 15845 ] {} TCPHandler: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003adff16b 3. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003ade861b 4. ./build_docker/./src/Server/TCPHandler.cpp:1241: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe46c 5. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 08:49:21.650362 [ 15862 ] {1a6fb1db-f989-4c95-a50b-f558d01318ce} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:40072). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:40072) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: SELECT `__table1`.`number` AS `number` FROM numbers(20) AS `__table1` LIMIT _CAST(8, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc8fc3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe68d 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:49:21.661334 [ 15862 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:40072). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc8fc3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe68d 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:49:23.208762 [ 15860 ] {d38723c8-29be-43fa-ba9d-4d8cbb597aaf} executeQuery: Code: 128. DB::Exception: Function mapPopulateSeries too large array size in the result: In scope SELECT mapPopulateSeries([-9223372036854775808, toUInt32(2)], [toUInt32(1023), -1]). (TOO_LARGE_ARRAY_SIZE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49490) (comment: 01777_map_populate_series_ubsan.sql) (query 1, line 1) (in query: -- Should correctly throw exception about overflow: SELECT mapPopulateSeries([-9223372036854775808, toUInt32(2)], [toUInt32(1023), -1]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. void DB::FunctionMapPopulateSeries::executeImplTyped(COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::mutable_ptr, COW::mutable_ptr, COW::mutable_ptr) const @ 0x000000001f2e056f 5. auto DB::FunctionMapPopulateSeries::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator(), DB::DataTypeNumber>>(auto const&) const @ 0x000000001f2decdd 6. DB::FunctionMapPopulateSeries::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ed8df15 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 2025.06.13 08:49:23.217315 [ 15860 ] {} TCPHandler: Code: 128. DB::Exception: Function mapPopulateSeries too large array size in the result: In scope SELECT mapPopulateSeries([-9223372036854775808, toUInt32(2)], [toUInt32(1023), -1]). (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. void DB::FunctionMapPopulateSeries::executeImplTyped(COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::mutable_ptr, COW::mutable_ptr, COW::mutable_ptr) const @ 0x000000001f2e056f 5. auto DB::FunctionMapPopulateSeries::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator(), DB::DataTypeNumber>>(auto const&) const @ 0x000000001f2decdd 6. DB::FunctionMapPopulateSeries::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ed8df15 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 2025.06.13 08:49:26.524519 [ 15865 ] {3d3b0e6d-f37e-4a03-9537-ac5c01e03dae} executeQuery: Code: 6. DB::Exception: Cannot parse string 'a' as UInt8: syntax error at begin of string. Note: there are toUInt8OrZero and toUInt8OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION nullIn('a'_String :: 2, __set_16477601970968652312_17741534445838362424 :: 1) -> nullIn('a'_String, __set_16477601970968652312_17741534445838362424) UInt8 : 3'. (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49480) (comment: 01600_select_in_different_types.sql) (query 22, line 33) (in query: SELECT 'a' IN (SELECT 1) SETTINGS transform_null_in = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000008ea7006 4. COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::FunctionCastName, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::AccurateConvertStrategyAdditions) @ 0x000000002c28d45c 5. bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)::operator()>>(DB::DataTypeNumber const&) const @ 0x000000002c2648be 6. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c25e184 7. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c25dc04 8. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff69df 13. ./build_docker/./src/Interpreters/castColumn.cpp:39: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000336772b9 14. ./build_docker/./src/Interpreters/castColumn.cpp:49: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x000000003367899c 15. ./build_docker/./src/Interpreters/Set.cpp:440: DB::Set::execute(std::vector> const&, bool) const @ 0x0000000032f4fa0c 16. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, bool, unsigned long) const @ 0x000000001161a9b5 17. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011618cd0 18. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 22. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 23. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 24. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 25. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 2025.06.13 08:49:26.589019 [ 15865 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string 'a' as UInt8: syntax error at begin of string. Note: there are toUInt8OrZero and toUInt8OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION nullIn('a'_String :: 2, __set_16477601970968652312_17741534445838362424 :: 1) -> nullIn('a'_String, __set_16477601970968652312_17741534445838362424) UInt8 : 3'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000008ea7006 4. COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::FunctionCastName, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::AccurateConvertStrategyAdditions) @ 0x000000002c28d45c 5. bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)::operator()>>(DB::DataTypeNumber const&) const @ 0x000000002c2648be 6. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c25e184 7. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c25dc04 8. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff69df 13. ./build_docker/./src/Interpreters/castColumn.cpp:39: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000336772b9 14. ./build_docker/./src/Interpreters/castColumn.cpp:49: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x000000003367899c 15. ./build_docker/./src/Interpreters/Set.cpp:440: DB::Set::execute(std::vector> const&, bool) const @ 0x0000000032f4fa0c 16. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, bool, unsigned long) const @ 0x000000001161a9b5 17. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011618cd0 18. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 22. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 23. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 24. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 25. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:49:27.177884 [ 15865 ] {0ef6c01a-7827-4933-9669-8c914900b6ac} executeQuery: Code: 70. DB::Exception: Value in column Int8 cannot be safely converted into type UInt8: while executing 'FUNCTION nullIn(-1_Int8 :: 2, __set_16477601970968652312_17741534445838362424 :: 1) -> nullIn(-1_Int8, __set_16477601970968652312_17741534445838362424) UInt8 : 3'. (CANNOT_CONVERT_TYPE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49480) (comment: 01600_select_in_different_types.sql) (query 24, line 35) (in query: SELECT -1 IN (SELECT 1) SETTINGS transform_null_in = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. COW::immutable_ptr> DB::detail::ConvertImpl, DB::DataTypeNumber, DB::detail::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::vector::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, DB::detail::AccurateConvertStrategyAdditions) @ 0x000000002c273ff5 5. bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)::operator(), DB::DataTypeNumber>>(DB::DataTypeNumber const&) const @ 0x000000002c260f61 6. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c25e0d9 7. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c25dc04 8. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff69df 13. ./build_docker/./src/Interpreters/castColumn.cpp:39: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000336772b9 14. ./build_docker/./src/Interpreters/castColumn.cpp:49: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x000000003367899c 15. ./build_docker/./src/Interpreters/Set.cpp:440: DB::Set::execute(std::vector> const&, bool) const @ 0x0000000032f4fa0c 16. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, bool, unsigned long) const @ 0x000000001161a9b5 17. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011618cd0 18. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 22. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 23. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 24. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 25. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 2025.06.13 08:49:27.223245 [ 15865 ] {} TCPHandler: Code: 70. DB::Exception: Value in column Int8 cannot be safely converted into type UInt8: while executing 'FUNCTION nullIn(-1_Int8 :: 2, __set_16477601970968652312_17741534445838362424 :: 1) -> nullIn(-1_Int8, __set_16477601970968652312_17741534445838362424) UInt8 : 3'. (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. COW::immutable_ptr> DB::detail::ConvertImpl, DB::DataTypeNumber, DB::detail::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::vector::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, DB::detail::AccurateConvertStrategyAdditions) @ 0x000000002c273ff5 5. bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)::operator(), DB::DataTypeNumber>>(DB::DataTypeNumber const&) const @ 0x000000002c260f61 6. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c25e0d9 7. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c25dc04 8. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff69df 13. ./build_docker/./src/Interpreters/castColumn.cpp:39: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000336772b9 14. ./build_docker/./src/Interpreters/castColumn.cpp:49: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x000000003367899c 15. ./build_docker/./src/Interpreters/Set.cpp:440: DB::Set::execute(std::vector> const&, bool) const @ 0x0000000032f4fa0c 16. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, bool, unsigned long) const @ 0x000000001161a9b5 17. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011618cd0 18. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 22. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 23. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 24. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 25. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:49:45.444181 [ 15867 ] {ea31a1c8-2443-45fa-8447-366f0f24c596} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:56550) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSON settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:49:45.450652 [ 15867 ] {ea31a1c8-2443-45fa-8447-366f0f24c596} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:45.495725 [ 15875 ] {7befef89-c296-4a9b-862e-8121d22bc24a} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:56564) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSONEachRow settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:49:45.500367 [ 15875 ] {7befef89-c296-4a9b-862e-8121d22bc24a} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:45.549348 [ 15867 ] {968c9f41-1882-43cd-b33b-cefbbb36706d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:56574) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSONCompact settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:49:45.553758 [ 15867 ] {968c9f41-1882-43cd-b33b-cefbbb36706d} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:45.589436 [ 15875 ] {52d1027f-920b-4550-9f09-3fff261dc55c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:56584) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSONCompactEachRow settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:49:45.593450 [ 15875 ] {52d1027f-920b-4550-9f09-3fff261dc55c} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:45.641681 [ 15875 ] {6c46d583-de56-4c8e-bcd7-2225165e830c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:56598) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSONObjectEachRow settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:49:45.647170 [ 15875 ] {6c46d583-de56-4c8e-bcd7-2225165e830c} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:45.684630 [ 15867 ] {ce05c77b-d51d-4862-ae49-5a1bec8a1b8e} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:56606) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format XML settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:49:45.690341 [ 15867 ] {ce05c77b-d51d-4862-ae49-5a1bec8a1b8e} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:45.733501 [ 2136 ] {672d7a83-d180-4010-b018-3200a3ebf970} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:56616) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSON settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:49:45.768533 [ 2136 ] {672d7a83-d180-4010-b018-3200a3ebf970} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:45.816430 [ 15860 ] {15e01416-6ed4-4218-a5e5-29568c56ce42} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:56624) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSONEachRow settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:49:45.823751 [ 15860 ] {15e01416-6ed4-4218-a5e5-29568c56ce42} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:45.869686 [ 2136 ] {e5ba3726-817c-4c21-87ad-aa4770381fba} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:56636) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSONCompact settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:49:45.876347 [ 2136 ] {e5ba3726-817c-4c21-87ad-aa4770381fba} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:45.912007 [ 15871 ] {caee75dc-f1b7-4ce8-bd7c-5d9545c3ce3f} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:56642) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSONCompactEachRow settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:49:45.919832 [ 15871 ] {caee75dc-f1b7-4ce8-bd7c-5d9545c3ce3f} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:45.977909 [ 15861 ] {aa8911a4-0fb7-47df-a848-653ca77e2b3c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:56646) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSONObjectEachRow settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:49:45.984807 [ 15861 ] {aa8911a4-0fb7-47df-a848-653ca77e2b3c} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:46.025432 [ 15871 ] {57a310e5-bfa2-4dbd-8fa3-06bc1a750322} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:56660) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format XML settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:49:46.034189 [ 15871 ] {57a310e5-bfa2-4dbd-8fa3-06bc1a750322} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:46.079128 [ 15861 ] {845ad10c-b5bf-4965-8690-b0e57b4b7191} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:56662) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSON settings max_block_size=1, output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:49:46.083886 [ 15861 ] {845ad10c-b5bf-4965-8690-b0e57b4b7191} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:46.120589 [ 15865 ] {8d4a5d83-5bd0-485c-940f-fb2bae254a54} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:56676) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSONEachRow settings max_block_size=1, output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:49:46.124928 [ 15865 ] {8d4a5d83-5bd0-485c-940f-fb2bae254a54} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:46.163295 [ 15865 ] {f0805b94-1727-4ecc-83cb-f3c071925086} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:56678) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSONCompact settings max_block_size=1, output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:49:46.166587 [ 15865 ] {f0805b94-1727-4ecc-83cb-f3c071925086} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:46.210139 [ 15865 ] {3df30c92-1866-4935-a85f-ab9d91c3ecfc} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:56694) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSONCompactEachRow settings max_block_size=1, output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:49:46.214321 [ 15865 ] {3df30c92-1866-4935-a85f-ab9d91c3ecfc} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:46.264696 [ 15865 ] {d765423b-885b-4967-b424-87b89fd9b7a1} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:56710) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSONObjectEachRow settings max_block_size=1, output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:49:46.267722 [ 15865 ] {d765423b-885b-4967-b424-87b89fd9b7a1} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:46.307383 [ 15865 ] {adb937e1-d992-4a46-b640-7b58cc59bdd5} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:56720) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format XML settings max_block_size=1, output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:49:46.310708 [ 15865 ] {adb937e1-d992-4a46-b640-7b58cc59bdd5} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:46.364027 [ 15865 ] {4b743276-6746-4f14-8f3e-4779bf22141d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:56730) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSON settings max_block_size=1, output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:49:46.370542 [ 15865 ] {4b743276-6746-4f14-8f3e-4779bf22141d} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:47.064552 [ 15871 ] {17e87d1c-01ec-4d2e-a32b-8363df3f4971} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:56736) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSONCompact settings max_block_size=1, output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:49:47.075724 [ 15871 ] {17e87d1c-01ec-4d2e-a32b-8363df3f4971} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:47.701834 [ 9224 ] {756f2f5a-197b-4a38-b6f7-bbfc51584e73} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:56738) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSONObjectEachRow settings max_block_size=1, output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:49:47.709645 [ 9224 ] {756f2f5a-197b-4a38-b6f7-bbfc51584e73} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:48.331910 [ 15871 ] {068eff7a-efce-468b-9571-249b5d41ecd3} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:56750) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSONEachRow settings max_block_size=1, output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:49:48.338790 [ 15871 ] {068eff7a-efce-468b-9571-249b5d41ecd3} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:49.059085 [ 9220 ] {d6504ce9-335e-4f97-a6da-9441076eaf95} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:56752) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSONCompactEachRow settings max_block_size=1, output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:49:49.072895 [ 9220 ] {d6504ce9-335e-4f97-a6da-9441076eaf95} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:51.269880 [ 9220 ] {cd060117-dd3c-4183-b451-69488e7204b1} executeQuery: Code: 403. DB::Exception: Cannot determine join keys in JOIN ON expression [Predcates: () Right filter: ((not(equals(__table2.x, __table2.x))))]. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41894) (comment: 03362_join_where_false_76670.sql) (query 8, line 12) (in query: SELECT * FROM t1 RIGHT JOIN t0 AS t2 ON NOT t0.x = t2.x WHERE false ;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:572: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003c09ee0f 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x000000003c3e710a 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c3be655 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f95f8 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:49:51.273337 [ 9220 ] {} TCPHandler: Code: 403. DB::Exception: Cannot determine join keys in JOIN ON expression [Predcates: () Right filter: ((not(equals(__table2.x, __table2.x))))]. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:572: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003c09ee0f 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x000000003c3e710a 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c3be655 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f95f8 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:49:51.769812 [ 9263 ] {0b243b44-7212-4775-8088-0b9154d298ba} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `lambda_2` in scope WITH x -> toString(x) AS lambda_1 SELECT 3, arrayMap(lambda_1 AS lambda_2, [1, 2, 3]), arrayMap(lambda_2, materialize(['1', '2', '3'])) WHERE toNullable(9) GROUP BY lambda_2. Maybe you meant: ['lambda_2']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41928) (comment: 03358_lambda_resolution_segfault_analyzer.sql) (query 2, line 2) (in query: WITH x -> toString(x) AS lambda_1 SELECT 3, arrayMap(lambda_1 AS lambda_2, [1, 2, 3]), arrayMap(lambda_2, materialize(['1', '2', '3'])) WHERE toNullable(9) GROUP BY lambda_2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000303dd3a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032b465 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4227: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x00000000303bd14f 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5618: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030d524 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:49:51.774623 [ 9263 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `lambda_2` in scope WITH x -> toString(x) AS lambda_1 SELECT 3, arrayMap(lambda_1 AS lambda_2, [1, 2, 3]), arrayMap(lambda_2, materialize(['1', '2', '3'])) WHERE toNullable(9) GROUP BY lambda_2. Maybe you meant: ['lambda_2']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000303dd3a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032b465 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4227: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x00000000303bd14f 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5618: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030d524 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:49:56.624306 [ 2141 ] {eb042423-041b-42ab-97a0-24b73d4d3384} executeQuery: Code: 47. DB::Exception: JOIN INNER JOIN ... USING (b) using identifier 'b' cannot be resolved from right table expression. In scope SELECT 1 AS b FROM tb INNER JOIN ta USING (b). (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49926) (comment: 02989_join_using_parent_scope.sql) (query 17, line 24) (in query: SELECT 1 AS b FROM tb JOIN ta USING (b);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000303de2b7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5272: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303d4049 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f5a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:49:56.629485 [ 2141 ] {} TCPHandler: Code: 47. DB::Exception: JOIN INNER JOIN ... USING (b) using identifier 'b' cannot be resolved from right table expression. In scope SELECT 1 AS b FROM tb INNER JOIN ta USING (b). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000303de2b7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5272: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303d4049 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f5a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:49:57.847298 [ 4332 ] {78df6ab8-a3ac-49ad-b731-2796278433f6} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48502) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 order by x format JSON settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. DB::ISerialization::serializeTextJSONPretty(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&, unsigned long) const @ 0x0000000008dcf5c0 7. ./build_docker/./src/Formats/JSONUtils.cpp:426: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af945d2 8. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:38: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4dc0e5 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 12. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:49:57.953690 [ 4332 ] {78df6ab8-a3ac-49ad-b731-2796278433f6} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. DB::ISerialization::serializeTextJSONPretty(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&, unsigned long) const @ 0x0000000008dcf5c0 7. ./build_docker/./src/Formats/JSONUtils.cpp:426: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af945d2 8. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:38: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4dc0e5 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 12. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 9. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:58.078560 [ 9262 ] {00e87e9c-a677-4923-aa66-6820be43999b} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONEachRowRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48508) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 order by x format JSONEachRow settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af947ba 7. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowOutputFormat.cpp:30: DB::JSONEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4cded5 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 11. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:49:58.083511 [ 9262 ] {00e87e9c-a677-4923-aa66-6820be43999b} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONEachRowRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af947ba 7. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowOutputFormat.cpp:30: DB::JSONEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4cded5 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 11. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 9. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:58.301374 [ 9229 ] {d21fc461-762f-4ba0-b172-45c25872c0ff} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONCompactRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48512) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 order by x format JSONCompact settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af947ba 7. ./build_docker/./src/Processors/Formats/Impl/JSONCompactRowOutputFormat.cpp:22: DB::JSONCompactRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4bf666 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 11. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:49:58.306988 [ 9229 ] {d21fc461-762f-4ba0-b172-45c25872c0ff} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONCompactRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af947ba 7. ./build_docker/./src/Processors/Formats/Impl/JSONCompactRowOutputFormat.cpp:22: DB::JSONCompactRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4bf666 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 11. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 9. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:58.499906 [ 2134 ] {33dacd33-7373-4884-9740-b823f57696dc} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONCompactEachRowRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48516) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 order by x format JSONCompactEachRow settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. ./build_docker/./src/Processors/Formats/Impl/JSONCompactEachRowRowOutputFormat.cpp:37: DB::JSONCompactEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4b417f 7. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 8. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 10. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:49:58.505071 [ 2134 ] {33dacd33-7373-4884-9740-b823f57696dc} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONCompactEachRowRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. ./build_docker/./src/Processors/Formats/Impl/JSONCompactEachRowRowOutputFormat.cpp:37: DB::JSONCompactEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4b417f 7. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 8. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 10. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 9. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:58.651375 [ 2141 ] {b425d920-c07a-46e8-8f2a-e34fa23a72ef} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `a` in scope SELECT a + 2 AS b FROM test_dfd3i4fx.tb. Maybe you meant: ['b']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49926) (comment: 02989_join_using_parent_scope.sql) (query 30, line 44) (in query: -- It's a default behavior for old analyzer and new with analyzer_compatibility_join_using_top_level_identifier -- Column `b` actually exists in left table, but `b` from USING is resoled to `a + 2` and `a` is not in left table -- so we get UNKNOWN_IDENTIFIER error. SELECT a + 2 AS b FROM tb JOIN tabc USING (b) ORDER BY ALL SETTINGS analyzer_compatibility_join_using_top_level_identifier = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000303dd3a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032b465 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5199: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303cfd0e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f5a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:49:58.655346 [ 2141 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `a` in scope SELECT a + 2 AS b FROM test_dfd3i4fx.tb. Maybe you meant: ['b']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000303dd3a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032b465 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5199: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303cfd0e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f5a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:49:58.704336 [ 4332 ] {0bc8894a-6f72-4b53-8e50-8015cbe2e003} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONObjectEachRowRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48532) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 order by x format JSONObjectEachRow settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af947ba 7. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowOutputFormat.cpp:30: DB::JSONEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4cded5 8. ./build_docker/./src/Processors/Formats/Impl/JSONObjectEachRowRowOutputFormat.cpp:23: DB::JSONObjectEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4d5e2f 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::JSONObjectEachRowRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4d6441 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 12. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:49:58.711070 [ 4332 ] {0bc8894a-6f72-4b53-8e50-8015cbe2e003} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONObjectEachRowRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af947ba 7. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowOutputFormat.cpp:30: DB::JSONEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4cded5 8. ./build_docker/./src/Processors/Formats/Impl/JSONObjectEachRowRowOutputFormat.cpp:23: DB::JSONObjectEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4d5e2f 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::JSONObjectEachRowRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4d6441 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 12. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 9. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:58.887040 [ 5285 ] {44b4c15f-93f9-49f2-9db2-3928c4906986} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing XMLRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48540) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 order by x format XML settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextXML(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f596606 6. ./build_docker/./src/Processors/Formats/Impl/XMLRowOutputFormat.cpp:79: DB::XMLRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b967737 7. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 8. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 10. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:49:58.894147 [ 5285 ] {44b4c15f-93f9-49f2-9db2-3928c4906986} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing XMLRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextXML(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f596606 6. ./build_docker/./src/Processors/Formats/Impl/XMLRowOutputFormat.cpp:79: DB::XMLRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b967737 7. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 8. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 10. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 9. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:59.105327 [ 2135 ] {3036191f-8565-461e-92da-272ce2b0f646} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48546) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSON settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. DB::ISerialization::serializeTextJSONPretty(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&, unsigned long) const @ 0x0000000008dcf5c0 7. ./build_docker/./src/Formats/JSONUtils.cpp:426: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af945d2 8. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:38: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4dc0e5 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 12. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:228: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000003b5f5afc 13. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:298: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b5f9ac3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:49:59.182514 [ 2135 ] {3036191f-8565-461e-92da-272ce2b0f646} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. DB::ISerialization::serializeTextJSONPretty(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&, unsigned long) const @ 0x0000000008dcf5c0 7. ./build_docker/./src/Formats/JSONUtils.cpp:426: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af945d2 8. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:38: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4dc0e5 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 12. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:228: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000003b5f5afc 13. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:298: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b5f9ac3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x000000003b5f6cb7 5. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b5f3c38 6. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:157: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x000000003b5f7ebd 7. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 9. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:49:59.825953 [ 9261 ] {d09e554e-86a7-401a-a687-0ad32057145b} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48548) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSONCompact settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af947ba 7. ./build_docker/./src/Processors/Formats/Impl/JSONCompactRowOutputFormat.cpp:22: DB::JSONCompactRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4bf666 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 11. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:228: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000003b5f5afc 12. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:298: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b5f9ac3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:49:59.833083 [ 9261 ] {d09e554e-86a7-401a-a687-0ad32057145b} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af947ba 7. ./build_docker/./src/Processors/Formats/Impl/JSONCompactRowOutputFormat.cpp:22: DB::JSONCompactRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4bf666 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 11. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:228: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000003b5f5afc 12. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:298: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b5f9ac3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x000000003b5f6cb7 5. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b5f3c38 6. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:157: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x000000003b5f7ebd 7. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 9. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:00.460793 [ 5285 ] {b584e4c3-3b9d-42e8-babb-e8f64e6f2184} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48550) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSONObjectEachRow settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af947ba 7. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowOutputFormat.cpp:30: DB::JSONEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4cded5 8. ./build_docker/./src/Processors/Formats/Impl/JSONObjectEachRowRowOutputFormat.cpp:23: DB::JSONObjectEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4d5e2f 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::JSONObjectEachRowRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4d6441 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 12. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:228: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000003b5f5afc 13. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:298: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b5f9ac3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:50:00.467875 [ 5285 ] {b584e4c3-3b9d-42e8-babb-e8f64e6f2184} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af947ba 7. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowOutputFormat.cpp:30: DB::JSONEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4cded5 8. ./build_docker/./src/Processors/Formats/Impl/JSONObjectEachRowRowOutputFormat.cpp:23: DB::JSONObjectEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4d5e2f 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::JSONObjectEachRowRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4d6441 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 12. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:228: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000003b5f5afc 13. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:298: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b5f9ac3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x000000003b5f6cb7 5. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b5f3c38 6. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:157: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x000000003b5f7ebd 7. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 9. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:01.131202 [ 4332 ] {18d461e1-3558-47b9-a33a-621809e7a985} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48556) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSONEachRow settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af947ba 7. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowOutputFormat.cpp:30: DB::JSONEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4cded5 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 11. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:228: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000003b5f5afc 12. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:298: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b5f9ac3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:50:01.154653 [ 4332 ] {18d461e1-3558-47b9-a33a-621809e7a985} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af947ba 7. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowOutputFormat.cpp:30: DB::JSONEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4cded5 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 11. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:228: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000003b5f5afc 12. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:298: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b5f9ac3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x000000003b5f6cb7 5. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b5f3c38 6. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:157: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x000000003b5f7ebd 7. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 9. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:01.795753 [ 15838 ] {ab0386ce-1e05-472b-ad71-41012a69df53} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48568) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSONCompactEachRow settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. ./build_docker/./src/Processors/Formats/Impl/JSONCompactEachRowRowOutputFormat.cpp:37: DB::JSONCompactEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4b417f 7. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 8. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 10. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:228: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000003b5f5afc 11. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:298: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b5f9ac3 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 08:50:01.802695 [ 15838 ] {ab0386ce-1e05-472b-ad71-41012a69df53} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. ./build_docker/./src/Processors/Formats/Impl/JSONCompactEachRowRowOutputFormat.cpp:37: DB::JSONCompactEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4b417f 7. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 8. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 10. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:228: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000003b5f5afc 11. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:298: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b5f9ac3 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x000000003b5f6cb7 5. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b5f3c38 6. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:157: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x000000003b5f7ebd 7. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 9. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:03.946958 [ 15839 ] {baf858c5-dd1e-4e54-9536-6bb885373cab} executeQuery: Code: 43. DB::Exception: Illegal interval kind for argument data type DateTime: In scope SELECT dateTrunc('Nanosecond', toDateTime('2022-03-01')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50332) (comment: 02935_date_trunc_case_unsensitiveness.sql) (query 22, line 22) (in query: SELECT dateTrunc('Nanosecond', toDateTime('2022-03-01'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x0000000012877c0a 4. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDateTime const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000001ab7a12a 5. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000001aaf62af 6. DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aaf1e42 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff69df 12. DB::(anonymous namespace)::FunctionDateTrunc::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d29ddc7 13. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 14. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 16. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 2025.06.13 08:50:03.950544 [ 15839 ] {} TCPHandler: Code: 43. DB::Exception: Illegal interval kind for argument data type DateTime: In scope SELECT dateTrunc('Nanosecond', toDateTime('2022-03-01')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x0000000012877c0a 4. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDateTime const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000001ab7a12a 5. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000001aaf62af 6. DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aaf1e42 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff69df 12. DB::(anonymous namespace)::FunctionDateTrunc::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d29ddc7 13. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 14. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 16. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 2025.06.13 08:50:03.972288 [ 15839 ] {d9b8e3ce-2a1d-4075-ae21-ae684f3bd171} executeQuery: Code: 43. DB::Exception: Illegal interval kind for argument data type DateTime: In scope SELECT dateTrunc('MicroSecond', toDateTime('2022-03-01')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50332) (comment: 02935_date_trunc_case_unsensitiveness.sql) (query 23, line 23) (in query: SELECT dateTrunc('MicroSecond', toDateTime('2022-03-01'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x0000000012877c0a 4. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDateTime const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000001ab7a12a 5. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000001aaf62af 6. DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aaf1e42 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff69df 12. DB::(anonymous namespace)::FunctionDateTrunc::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d29ddc7 13. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 14. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 16. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 2025.06.13 08:50:03.976043 [ 15839 ] {} TCPHandler: Code: 43. DB::Exception: Illegal interval kind for argument data type DateTime: In scope SELECT dateTrunc('MicroSecond', toDateTime('2022-03-01')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x0000000012877c0a 4. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDateTime const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000001ab7a12a 5. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000001aaf62af 6. DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aaf1e42 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff69df 12. DB::(anonymous namespace)::FunctionDateTrunc::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d29ddc7 13. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 14. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 16. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 2025.06.13 08:50:03.997519 [ 15839 ] {47924348-e5cc-4dfe-984c-9dd0344974a3} executeQuery: Code: 43. DB::Exception: Illegal interval kind for argument data type DateTime: In scope SELECT dateTrunc('MILLISECOND', toDateTime('2022-03-01')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50332) (comment: 02935_date_trunc_case_unsensitiveness.sql) (query 24, line 24) (in query: SELECT dateTrunc('MILLISECOND', toDateTime('2022-03-01'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x0000000012877c0a 4. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDateTime const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000001ab7a12a 5. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000001aaf62af 6. DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aaf1e42 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff69df 12. DB::(anonymous namespace)::FunctionDateTrunc::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d29ddc7 13. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 14. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 16. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 2025.06.13 08:50:04.001401 [ 15839 ] {} TCPHandler: Code: 43. DB::Exception: Illegal interval kind for argument data type DateTime: In scope SELECT dateTrunc('MILLISECOND', toDateTime('2022-03-01')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x0000000012877c0a 4. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDateTime const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000001ab7a12a 5. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000001aaf62af 6. DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aaf1e42 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff69df 12. DB::(anonymous namespace)::FunctionDateTrunc::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d29ddc7 13. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 14. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 16. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 2025.06.13 08:50:04.285925 [ 15839 ] {9a14765a-9180-4306-9067-6d2793f329e3} executeQuery: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope SELECT dateTrunc('Nanosecond', toDate('2022-03-01')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50332) (comment: 02935_date_trunc_case_unsensitiveness.sql) (query 25, line 25) (in query: SELECT dateTrunc('Nanosecond', toDate('2022-03-01'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x0000000012877c0a 4. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000001ab7766a 5. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000001aaf60b9 6. DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aaf1e42 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff69df 12. DB::(anonymous namespace)::FunctionDateTrunc::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d29ddc7 13. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 14. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 16. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 2025.06.13 08:50:04.289464 [ 15839 ] {} TCPHandler: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope SELECT dateTrunc('Nanosecond', toDate('2022-03-01')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x0000000012877c0a 4. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000001ab7766a 5. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000001aaf60b9 6. DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aaf1e42 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff69df 12. DB::(anonymous namespace)::FunctionDateTrunc::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d29ddc7 13. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 14. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 16. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 2025.06.13 08:50:04.320562 [ 15839 ] {92cb6a18-97fa-4422-a884-cd0aa2edb0e9} executeQuery: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope SELECT dateTrunc('MicroSecond', toDate('2022-03-01')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50332) (comment: 02935_date_trunc_case_unsensitiveness.sql) (query 26, line 26) (in query: SELECT dateTrunc('MicroSecond', toDate('2022-03-01'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x0000000012877c0a 4. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000001ab7766a 5. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000001aaf60b9 6. DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aaf1e42 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff69df 12. DB::(anonymous namespace)::FunctionDateTrunc::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d29ddc7 13. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 14. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 16. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 2025.06.13 08:50:04.324941 [ 15839 ] {} TCPHandler: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope SELECT dateTrunc('MicroSecond', toDate('2022-03-01')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x0000000012877c0a 4. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000001ab7766a 5. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000001aaf60b9 6. DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aaf1e42 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff69df 12. DB::(anonymous namespace)::FunctionDateTrunc::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d29ddc7 13. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 14. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 16. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 2025.06.13 08:50:04.352412 [ 15839 ] {1e11a242-4939-4ffd-9d09-a30dfa52e31c} executeQuery: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope SELECT dateTrunc('MILLISECOND', toDate('2022-03-01')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50332) (comment: 02935_date_trunc_case_unsensitiveness.sql) (query 27, line 27) (in query: SELECT dateTrunc('MILLISECOND', toDate('2022-03-01'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x0000000012877c0a 4. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000001ab7766a 5. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000001aaf60b9 6. DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aaf1e42 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff69df 12. DB::(anonymous namespace)::FunctionDateTrunc::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d29ddc7 13. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 14. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 16. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 2025.06.13 08:50:04.356978 [ 15839 ] {} TCPHandler: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope SELECT dateTrunc('MILLISECOND', toDate('2022-03-01')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x0000000012877c0a 4. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000001ab7766a 5. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000001aaf60b9 6. DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aaf1e42 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff69df 12. DB::(anonymous namespace)::FunctionDateTrunc::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d29ddc7 13. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 14. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 16. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 2025.06.13 08:50:06.714850 [ 2136 ] {1e6f906d-c92f-4289-a5e5-66336323562e} executeQuery: Code: 643. DB::Exception: Couldn't open archive '/var/lib/clickhouse/user_files/02994_file_1749822590/test.rar.7z': Unrecognized archive format: The table structure cannot be extracted from a CSV format file. You can specify the structure manually. (CANNOT_UNPACK_ARCHIVE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58314) (comment: 02994_libarchive_compression.sh) (query 1, line 1) (in query: SELECT c1 FROM file('02994_file_1749822590/test.rar.7z :: test.csv', CSV);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, char const*&&) @ 0x0000000026696fcd 4. ./build_docker/./src/IO/Archives/LibArchiveReader.cpp:240: DB::LibArchiveReader::Handle::openWithPath(String const&) @ 0x000000002d5071e5 5. ./build_docker/./src/IO/Archives/LibArchiveReader.cpp:43: DB::LibArchiveReader::Handle::Handle(String, bool) @ 0x000000002d503f4c 6. ./build_docker/./src/IO/Archives/LibArchiveReader.cpp:485: DB::LibArchiveReader::acquireHandle() @ 0x000000002d4fba4b 7. ./build_docker/./src/IO/Archives/LibArchiveReader.cpp:405: DB::LibArchiveReader::readFile(String const&, bool) @ 0x000000002d4fcbe9 8. ./build_docker/./src/Storages/StorageFile.cpp:702: DB::(anonymous namespace)::ReadBufferFromArchiveIterator::next() @ 0x000000003842e418 9. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:152: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003afcb1ca 10. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003afd97ae 11. ./build_docker/./src/Storages/StorageFile.cpp:978: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000383fa43a 12. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000383fbede 13. ./build_docker/./src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x00000000383fef51 14. ./build_docker/./src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x00000000384046c7 15. ./build_docker/./src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x0000000038406460 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x000000002660f915 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x0000000026609941 18. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002661374b 19. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d0326ad 20. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316edd5f 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030336f50 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 2025.06.13 08:50:06.720454 [ 2136 ] {} TCPHandler: Code: 643. DB::Exception: Couldn't open archive '/var/lib/clickhouse/user_files/02994_file_1749822590/test.rar.7z': Unrecognized archive format: The table structure cannot be extracted from a CSV format file. You can specify the structure manually. (CANNOT_UNPACK_ARCHIVE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, char const*&&) @ 0x0000000026696fcd 4. ./build_docker/./src/IO/Archives/LibArchiveReader.cpp:240: DB::LibArchiveReader::Handle::openWithPath(String const&) @ 0x000000002d5071e5 5. ./build_docker/./src/IO/Archives/LibArchiveReader.cpp:43: DB::LibArchiveReader::Handle::Handle(String, bool) @ 0x000000002d503f4c 6. ./build_docker/./src/IO/Archives/LibArchiveReader.cpp:485: DB::LibArchiveReader::acquireHandle() @ 0x000000002d4fba4b 7. ./build_docker/./src/IO/Archives/LibArchiveReader.cpp:405: DB::LibArchiveReader::readFile(String const&, bool) @ 0x000000002d4fcbe9 8. ./build_docker/./src/Storages/StorageFile.cpp:702: DB::(anonymous namespace)::ReadBufferFromArchiveIterator::next() @ 0x000000003842e418 9. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:152: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003afcb1ca 10. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003afd97ae 11. ./build_docker/./src/Storages/StorageFile.cpp:978: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000383fa43a 12. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000383fbede 13. ./build_docker/./src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x00000000383fef51 14. ./build_docker/./src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x00000000384046c7 15. ./build_docker/./src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x0000000038406460 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x000000002660f915 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x0000000026609941 18. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002661374b 19. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d0326ad 20. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316edd5f 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030336f50 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 2025.06.13 08:50:06.838861 [ 15841 ] {cb8777b4-f57e-4a7c-bc86-4802d5b75a1f} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:36468) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSON settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. DB::ISerialization::serializeTextJSONPretty(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&, unsigned long) const @ 0x0000000008dcf5c0 7. ./build_docker/./src/Formats/JSONUtils.cpp:426: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af945d2 8. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:38: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4dc0e5 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 12. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:50:06.845533 [ 15841 ] {cb8777b4-f57e-4a7c-bc86-4802d5b75a1f} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. DB::ISerialization::serializeTextJSONPretty(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&, unsigned long) const @ 0x0000000008dcf5c0 7. ./build_docker/./src/Formats/JSONUtils.cpp:426: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af945d2 8. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:38: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4dc0e5 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 12. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 9. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:06.940830 [ 9234 ] {37f3f98b-f1fc-43b1-9559-b5136ecc2cea} executeQuery: Code: 69. DB::Exception: Second argument (shingle size) of function wordShingleSimHash cannot be greater then 25: In scope SELECT wordShingleSimHash('foobar', 9223372036854775807). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50254) (comment: 01016_simhash_minhash.sql) (query 73, line 114) (in query: SELECT wordShingleSimHash('foobar', 9223372036854775807);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000982248d 4. DB::FunctionsStringHash, DB::NameWordShingleSimHash, true, false>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ac7e45d 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:50:06.944336 [ 9234 ] {} TCPHandler: Code: 69. DB::Exception: Second argument (shingle size) of function wordShingleSimHash cannot be greater then 25: In scope SELECT wordShingleSimHash('foobar', 9223372036854775807). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000982248d 4. DB::FunctionsStringHash, DB::NameWordShingleSimHash, true, false>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ac7e45d 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:50:06.963752 [ 9234 ] {8fcf2f57-2560-4dd4-a3bf-20b11381fde0} executeQuery: Code: 69. DB::Exception: Second argument (shingle size) of function wordShingleSimHash cannot be greater then 25: In scope SELECT wordShingleSimHash('foobar', 1001). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50254) (comment: 01016_simhash_minhash.sql) (query 74, line 115) (in query: SELECT wordShingleSimHash('foobar', 1001);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000982248d 4. DB::FunctionsStringHash, DB::NameWordShingleSimHash, true, false>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ac7e45d 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:50:06.966826 [ 9234 ] {} TCPHandler: Code: 69. DB::Exception: Second argument (shingle size) of function wordShingleSimHash cannot be greater then 25: In scope SELECT wordShingleSimHash('foobar', 1001). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000982248d 4. DB::FunctionsStringHash, DB::NameWordShingleSimHash, true, false>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ac7e45d 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:50:07.227176 [ 9234 ] {773ffaf5-d18a-4ac8-8bf4-bdb7d9bdc36a} executeQuery: Code: 69. DB::Exception: Second argument (shingle size) of function wordShingleSimHash cannot be zero: In scope SELECT wordShingleSimHash('foobar', 0). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50254) (comment: 01016_simhash_minhash.sql) (query 75, line 116) (in query: SELECT wordShingleSimHash('foobar', 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::FunctionsStringHash, DB::NameWordShingleSimHash, true, false>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ac7e281 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:50:07.230690 [ 9234 ] {} TCPHandler: Code: 69. DB::Exception: Second argument (shingle size) of function wordShingleSimHash cannot be zero: In scope SELECT wordShingleSimHash('foobar', 0). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::FunctionsStringHash, DB::NameWordShingleSimHash, true, false>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ac7e281 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:50:08.641988 [ 15861 ] {1103337c-d6c9-4964-ba04-f412a7952ddd} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:36470) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSON settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. DB::ISerialization::serializeTextJSONPretty(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&, unsigned long) const @ 0x0000000008dcf5c0 7. ./build_docker/./src/Formats/JSONUtils.cpp:426: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af945d2 8. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:38: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4dc0e5 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 12. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:228: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000003b5f5afc 13. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:298: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b5f9ac3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:50:08.651154 [ 15861 ] {1103337c-d6c9-4964-ba04-f412a7952ddd} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. DB::ISerialization::serializeTextJSONPretty(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&, unsigned long) const @ 0x0000000008dcf5c0 7. ./build_docker/./src/Formats/JSONUtils.cpp:426: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af945d2 8. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:38: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4dc0e5 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 12. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:228: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000003b5f5afc 13. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:298: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b5f9ac3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x000000003b5f6cb7 5. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b5f3c38 6. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:157: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x000000003b5f7ebd 7. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 9. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:09.201104 [ 15860 ] {bccefe07-ac5d-4b4d-bff8-c2affa350ecd} executeQuery: Code: 471. DB::Exception: Invalid type Bool for setting "header" only integer settings are supported. (INVALID_SETTING_VALUE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58386) (comment: 02271_fix_column_matcher_and_column_transformer.sql) (query 7, line 75) (in query: EXPLAIN PIPELINE header = true, compact = true WITH top_repos AS (SELECT repo_name FROM github_events__fuzz_0 WHERE (event_type = 'WatchEvent') AND (toDate(created_at) = (today() - 1)) GROUP BY repo_name ORDER BY count() DESC LIMIT 100 UNION DISTINCT SELECT repo_name FROM github_events__fuzz_0 WHERE (event_type = 'WatchEvent') AND (toMonday(created_at) = toMonday(today() - toIntervalWeek(1))) GROUP BY repo_name ORDER BY count() DESC LIMIT 100 UNION DISTINCT SELECT repo_name FROM github_events__fuzz_0 PREWHERE (event_type = 'WatchEvent') AND (toStartOfMonth(created_at) = (toStartOfMonth(today()) - toIntervalMonth(1))) GROUP BY repo_name ORDER BY count() DESC LIMIT 100 UNION DISTINCT SELECT repo_name FROM github_events WHERE (event_type = 'WatchEvent') AND (toYear(created_at) = (toYear(today()) - 1)) GROUP BY repo_name ORDER BY count() DESC LIMIT 100), last_day AS (SELECT repo_name, count() AS count_last_day, rowNumberInAllBlocks() + 1 AS position_last_day FROM github_events WHERE (repo_name IN (SELECT repo_name FROM top_repos)) AND (toDate(created_at) = (today() - 1)) GROUP BY repo_name ORDER BY count_last_day DESC), last_week AS (SELECT repo_name, count() AS count_last_week, rowNumberInAllBlocks() + 1 AS position_last_week FROM github_events WHERE (repo_name IN (SELECT repo_name FROM top_repos)) AND (toMonday(created_at) = (toMonday(today()) - toIntervalWeek(2))) GROUP BY repo_name ORDER BY count_last_week DESC), last_month AS (SELECT repo_name, count() AS count_last_month, rowNumberInAllBlocks() + 1 AS position_last_month FROM github_events__fuzz_0 WHERE ('deleted' = 4) AND in(repo_name) AND (toStartOfMonth(created_at) = (toStartOfMonth(today()) - toIntervalMonth(1))) GROUP BY repo_name ORDER BY count_last_month DESC) SELECT d.repo_name, COLUMNS(count) FROM last_day AS d INNER JOIN last_week AS w ON d.repo_name = w.repo_name INNER JOIN last_month AS m ON d.repo_name = m.repo_name format Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>, String const&>(int, FormatStringHelperImpl>>::type, std::type_identity::type>, std::basic_string_view>&&, String const&) @ 0x000000002d6f8dcd 4. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:367: DB::InterpreterExplainQuery::executeImpl() @ 0x000000003298c383 5. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x000000003297fbe4 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:50:09.205903 [ 15860 ] {} TCPHandler: Code: 471. DB::Exception: Invalid type Bool for setting "header" only integer settings are supported. (INVALID_SETTING_VALUE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>, String const&>(int, FormatStringHelperImpl>>::type, std::type_identity::type>, std::basic_string_view>&&, String const&) @ 0x000000002d6f8dcd 4. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:367: DB::InterpreterExplainQuery::executeImpl() @ 0x000000003298c383 5. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x000000003297fbe4 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:50:13.355074 [ 3255 ] {27cfd03a-bfcb-4b72-8cd3-5ac67329b475} executeQuery: Code: 48. DB::Exception: Cannot rename and modify the same column `value1_string` in a single ALTER query. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58740) (comment: 01281_alter_rename_and_other_renames.sql) (query 4, line 7) (in query: ALTER TABLE rename_table_multiple RENAME COLUMN value1 TO value1_string, MODIFY COLUMN value1_string String;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1486: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000038199f1b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 08:50:13.358782 [ 3255 ] {} TCPHandler: Code: 48. DB::Exception: Cannot rename and modify the same column `value1_string` in a single ALTER query. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1486: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000038199f1b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 08:50:13.525201 [ 3255 ] {c6e82d3e-422d-46d5-80b1-363383e5b66a} executeQuery: Code: 48. DB::Exception: Cannot rename and modify the same column `value1` in a single ALTER query. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58740) (comment: 01281_alter_rename_and_other_renames.sql) (query 5, line 8) (in query: ALTER TABLE rename_table_multiple MODIFY COLUMN value1 String, RENAME COLUMN value1 to value1_string;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1683: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819a1bb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 08:50:13.528868 [ 3255 ] {} TCPHandler: Code: 48. DB::Exception: Cannot rename and modify the same column `value1` in a single ALTER query. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1683: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819a1bb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 08:50:14.676664 [ 3255 ] {0b245e1e-82bf-40a7-ac29-d7020948dccc} executeQuery: Code: 48. DB::Exception: Cannot rename and modify the same column `value1_string` in a single ALTER query. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58740) (comment: 01281_alter_rename_and_other_renames.sql) (query 22, line 41) (in query: ALTER TABLE rename_table_multiple_compact RENAME COLUMN value1 TO value1_string, MODIFY COLUMN value1_string String;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1486: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000038199f1b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 08:50:14.679982 [ 3255 ] {} TCPHandler: Code: 48. DB::Exception: Cannot rename and modify the same column `value1_string` in a single ALTER query. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1486: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000038199f1b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 08:50:14.704327 [ 3255 ] {e00ed460-7cb5-4620-ac05-a4f524b78137} executeQuery: Code: 48. DB::Exception: Cannot rename and modify the same column `value1` in a single ALTER query. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58740) (comment: 01281_alter_rename_and_other_renames.sql) (query 23, line 42) (in query: ALTER TABLE rename_table_multiple_compact MODIFY COLUMN value1 String, RENAME COLUMN value1 to value1_string;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1683: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819a1bb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 08:50:14.708200 [ 3255 ] {} TCPHandler: Code: 48. DB::Exception: Cannot rename and modify the same column `value1` in a single ALTER query. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1683: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819a1bb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 08:50:15.168019 [ 9215 ] {dfeb0fe2-4e4b-4a14-b76e-81fc6b7e4955} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:33528) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSON settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. DB::ISerialization::serializeTextJSONPretty(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&, unsigned long) const @ 0x0000000008dcf5c0 7. ./build_docker/./src/Formats/JSONUtils.cpp:426: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af945d2 8. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:38: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4dc0e5 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 12. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:50:15.174399 [ 9215 ] {dfeb0fe2-4e4b-4a14-b76e-81fc6b7e4955} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. DB::ISerialization::serializeTextJSONPretty(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&, unsigned long) const @ 0x0000000008dcf5c0 7. ./build_docker/./src/Formats/JSONUtils.cpp:426: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af945d2 8. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:38: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4dc0e5 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 12. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 9. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:15.887268 [ 9224 ] {162acad2-20b3-4a50-9881-ff1a251b5910} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:33536) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSON settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. DB::ISerialization::serializeTextJSONPretty(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&, unsigned long) const @ 0x0000000008dcf5c0 7. ./build_docker/./src/Formats/JSONUtils.cpp:426: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af945d2 8. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:38: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4dc0e5 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 12. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:228: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000003b5f5afc 13. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:298: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b5f9ac3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:50:15.895936 [ 9224 ] {162acad2-20b3-4a50-9881-ff1a251b5910} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. DB::ISerialization::serializeTextJSONPretty(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&, unsigned long) const @ 0x0000000008dcf5c0 7. ./build_docker/./src/Formats/JSONUtils.cpp:426: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af945d2 8. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:38: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4dc0e5 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 12. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:228: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000003b5f5afc 13. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:298: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b5f9ac3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x000000003b5f6cb7 5. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b5f3c38 6. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:157: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x000000003b5f7ebd 7. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 9. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:18.040516 [ 2142 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:44630, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fbc2c6f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fbc3c01 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9b2eba 6. DB::ReadBuffer::next() @ 0x0000000008e83ccf 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003ad8c853 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:18.040887 [ 2142 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:44630, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fbc2c6f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fbc3c01 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9b2eba 6. DB::ReadBuffer::next() @ 0x0000000008e83ccf 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003ad8c853 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:18.121452 [ 9224 ] {69431ec5-e503-4598-af2a-7480d8e497b5} executeQuery: Code: 78. DB::Exception: Query has infile and was send directly to server. (UNKNOWN_TYPE_OF_QUERY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:33558) (comment: 02009_from_infile.sh) (in query: INSERT INTO test_infile_url FROM INFILE '/repo/tests/queries/0_stateless/test_m7pn2iwe/test_infile.gz' FORMAT CSV), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Processors/Transforms/getSourceFromASTInsertQuery.cpp:50: DB::getInputFormatFromASTInsertQuery(std::shared_ptr const&, bool, DB::Block const&, std::shared_ptr, std::shared_ptr const&) @ 0x000000003bc93fd4 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:804: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000329dfb6d 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x00000000329e3913 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 9. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 08:50:18.125006 [ 9224 ] {69431ec5-e503-4598-af2a-7480d8e497b5} DynamicQueryHandler: Code: 78. DB::Exception: Query has infile and was send directly to server. (UNKNOWN_TYPE_OF_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Processors/Transforms/getSourceFromASTInsertQuery.cpp:50: DB::getInputFormatFromASTInsertQuery(std::shared_ptr const&, bool, DB::Block const&, std::shared_ptr, std::shared_ptr const&) @ 0x000000003bc93fd4 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:804: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000329dfb6d 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x00000000329e3913 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 9. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:23.117024 [ 9263 ] {9f51b6be-5f92-48fb-903a-abeec52b9985} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48666) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSON settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. DB::ISerialization::serializeTextJSONPretty(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&, unsigned long) const @ 0x0000000008dcf5c0 7. ./build_docker/./src/Formats/JSONUtils.cpp:426: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af945d2 8. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:38: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4dc0e5 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 12. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:50:23.127234 [ 9263 ] {9f51b6be-5f92-48fb-903a-abeec52b9985} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. DB::ISerialization::serializeTextJSONPretty(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&, unsigned long) const @ 0x0000000008dcf5c0 7. ./build_docker/./src/Formats/JSONUtils.cpp:426: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af945d2 8. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:38: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4dc0e5 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 12. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 9. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:23.867837 [ 404 ] {6ee00521-bdcb-459a-a2ad-26931919537f} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48680) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSON settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. DB::ISerialization::serializeTextJSONPretty(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&, unsigned long) const @ 0x0000000008dcf5c0 7. ./build_docker/./src/Formats/JSONUtils.cpp:426: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af945d2 8. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:38: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4dc0e5 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 12. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:228: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000003b5f5afc 13. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:298: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b5f9ac3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:50:23.876349 [ 404 ] {6ee00521-bdcb-459a-a2ad-26931919537f} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. DB::ISerialization::serializeTextJSONPretty(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&, unsigned long) const @ 0x0000000008dcf5c0 7. ./build_docker/./src/Formats/JSONUtils.cpp:426: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af945d2 8. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:38: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4dc0e5 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 12. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:228: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000003b5f5afc 13. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:298: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b5f9ac3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x000000003b5f6cb7 5. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b5f3c38 6. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:157: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x000000003b5f7ebd 7. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 9. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:24.499957 [ 9237 ] {53d9023d-0d56-4de8-8e75-9720e7c11aa3} DynamicQueryHandler: Code: 271. DB::Exception: Too large uncompressed size: 4294967295. (CANNOT_DECOMPRESS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned int&) @ 0x00000000183a6cca 4. ./build_docker/./src/Compression/CompressionCodecMultiple.cpp:100: DB::CompressionCodecMultiple::doDecompressData(char const*, unsigned int, char*, unsigned int) const @ 0x000000003dc42111 5. ./build_docker/./src/Compression/ICompressionCodec.cpp:119: DB::ICompressionCodec::decompress(char const*, unsigned int, char*) const @ 0x000000003dd4f6f3 6. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:329: DB::CompressedReadBufferBase::decompress(DB::BufferBase::Buffer&, unsigned long, unsigned long) @ 0x000000003dc02579 7. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:24: non-virtual thunk to DB::CompressedReadBuffer::nextImpl() @ 0x000000003dbfcc46 8. DB::ReadBuffer::next() @ 0x0000000008e83ccf 9. ./build_docker/./src/IO/ReadBuffer.cpp:34: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000001f87aa86 10. DB::ReadBuffer::next() @ 0x0000000008e83ccf 11. ./src/IO/ReadBuffer.h:96: DB::ConcatReadBuffer::nextImpl() @ 0x00000000315a8937 12. DB::ReadBuffer::next() @ 0x0000000008e83ccf 13. ./src/IO/ReadBuffer.h:81: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000337403da 14. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 15. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 16. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:24.886305 [ 404 ] {885f554c-7488-4b02-b21a-e51df0cd2164} DynamicQueryHandler: Code: 246. DB::Exception: Wrong data for compression codec NONE: source_size (278) != uncompressed_size (33686018). (CORRUPTED_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int&, unsigned int&) @ 0x000000002bfbd46d 4. ./build_docker/./src/Compression/CompressionCodecNone.cpp:33: DB::CompressionCodecNone::doDecompressData(char const*, unsigned int, char*, unsigned int) const @ 0x000000003dc31edc 5. ./build_docker/./src/Compression/ICompressionCodec.cpp:119: DB::ICompressionCodec::decompress(char const*, unsigned int, char*) const @ 0x000000003dd4f6f3 6. ./build_docker/./src/Compression/CompressionCodecMultiple.cpp:114: DB::CompressionCodecMultiple::doDecompressData(char const*, unsigned int, char*, unsigned int) const @ 0x000000003dc412d7 7. ./build_docker/./src/Compression/ICompressionCodec.cpp:119: DB::ICompressionCodec::decompress(char const*, unsigned int, char*) const @ 0x000000003dd4f6f3 8. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:329: DB::CompressedReadBufferBase::decompress(DB::BufferBase::Buffer&, unsigned long, unsigned long) @ 0x000000003dc02579 9. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:24: non-virtual thunk to DB::CompressedReadBuffer::nextImpl() @ 0x000000003dbfcc46 10. DB::ReadBuffer::next() @ 0x0000000008e83ccf 11. ./build_docker/./src/IO/ReadBuffer.cpp:34: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000001f87aa86 12. DB::ReadBuffer::next() @ 0x0000000008e83ccf 13. ./src/IO/ReadBuffer.h:96: DB::ConcatReadBuffer::nextImpl() @ 0x00000000315a8937 14. DB::ReadBuffer::next() @ 0x0000000008e83ccf 15. ./src/IO/ReadBuffer.h:81: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000337403da 16. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 17. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:25.336225 [ 404 ] {2f2d8741-9bc3-4518-b7f1-739db42c4e65} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48702) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSON settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:50:25.340119 [ 404 ] {2f2d8741-9bc3-4518-b7f1-739db42c4e65} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:25.410640 [ 404 ] {7e5e3937-47a6-452c-884c-a301205b810b} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48716) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSONEachRow settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:50:25.414054 [ 404 ] {7e5e3937-47a6-452c-884c-a301205b810b} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:25.474695 [ 404 ] {9b4d7a67-3935-4f98-9f55-d8dbf86187ba} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48730) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSONCompact settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:50:25.477474 [ 404 ] {9b4d7a67-3935-4f98-9f55-d8dbf86187ba} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:25.523040 [ 404 ] {e497a773-004d-460e-b397-d77c3b272b53} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48738) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSONCompactEachRow settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:50:25.525583 [ 404 ] {e497a773-004d-460e-b397-d77c3b272b53} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:25.573604 [ 404 ] {535e4205-603c-4380-a68d-5e3fe442d3da} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48752) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSONObjectEachRow settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:50:25.576212 [ 404 ] {535e4205-603c-4380-a68d-5e3fe442d3da} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:25.603271 [ 9235 ] {cb877539-09fe-4538-b945-cfbf6e141cbf} executeQuery: Code: 36. DB::Exception: The nested column of first argument in function mapFromArrays must not contain NULLs: In scope SELECT mapFromArrays([toLowCardinality(toNullable(1)), toLowCardinality(CAST(NULL, 'Nullable(Int32)'))], [3, 4]) GROUP BY 1. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50892) (comment: 03399_lc_nullable_mapfromarrays.sql) (query 6, line 16) (in query: SELECT mapFromArrays( [toLowCardinality(toNullable(1)), toLowCardinality(cast(NULL as Nullable(Int32)))], [3, 4] ) GROUP BY 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionMapFromArrays::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001469a700 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 08:50:25.606712 [ 9235 ] {} TCPHandler: Code: 36. DB::Exception: The nested column of first argument in function mapFromArrays must not contain NULLs: In scope SELECT mapFromArrays([toLowCardinality(toNullable(1)), toLowCardinality(CAST(NULL, 'Nullable(Int32)'))], [3, 4]) GROUP BY 1. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionMapFromArrays::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001469a700 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 08:50:25.624583 [ 404 ] {92bffc55-96cc-4485-ba93-d49bcd774547} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48766) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format XML settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:50:25.627182 [ 404 ] {92bffc55-96cc-4485-ba93-d49bcd774547} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:25.639223 [ 9235 ] {626eabd6-acf5-4de9-a1d1-a6e674e95014} executeQuery: Code: 36. DB::Exception: The nested column of first argument in function mapFromArrays must not contain NULLs: In scope SELECT mapFromArrays([toLowCardinality(toNullable('x')), toLowCardinality(CAST(NULL, 'Nullable(String)'))], [3, 4]) GROUP BY 1. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50892) (comment: 03399_lc_nullable_mapfromarrays.sql) (query 7, line 21) (in query: SELECT mapFromArrays( [toLowCardinality(toNullable('x')), toLowCardinality(cast(NULL as Nullable(String)))], [3, 4] ) GROUP BY 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionMapFromArrays::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001469a700 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 08:50:25.642528 [ 9235 ] {} TCPHandler: Code: 36. DB::Exception: The nested column of first argument in function mapFromArrays must not contain NULLs: In scope SELECT mapFromArrays([toLowCardinality(toNullable('x')), toLowCardinality(CAST(NULL, 'Nullable(String)'))], [3, 4]) GROUP BY 1. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionMapFromArrays::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001469a700 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 08:50:25.700823 [ 4466 ] {6f93f9ca-361f-45eb-921c-4177840d7af3} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48770) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSON settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:50:25.704857 [ 4466 ] {6f93f9ca-361f-45eb-921c-4177840d7af3} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:25.770567 [ 9237 ] {5bd3c115-ae60-4c3d-882e-a1ad0a3d7816} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48776) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSONEachRow settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:50:25.774493 [ 9237 ] {5bd3c115-ae60-4c3d-882e-a1ad0a3d7816} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:25.840202 [ 4466 ] {ffc4d50a-386d-4da1-83c5-bbc4deb5a875} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48792) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSONCompact settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:50:25.844750 [ 4466 ] {ffc4d50a-386d-4da1-83c5-bbc4deb5a875} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:25.909757 [ 9237 ] {b830bd1b-d51a-419a-bc5a-8f96d31d12bf} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48804) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSONCompactEachRow settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:50:25.914219 [ 9237 ] {b830bd1b-d51a-419a-bc5a-8f96d31d12bf} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:25.967271 [ 9237 ] {1e9243cb-4348-471d-bc78-79aa45a9b786} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48806) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSONObjectEachRow settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:50:25.970447 [ 9237 ] {1e9243cb-4348-471d-bc78-79aa45a9b786} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:26.055218 [ 9237 ] {f610d305-5ac8-4dd5-848f-85ba29c6ba08} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48822) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format XML settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:50:26.059399 [ 9237 ] {f610d305-5ac8-4dd5-848f-85ba29c6ba08} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:26.118399 [ 4466 ] {62f52e9f-2609-4f80-b81c-85829fe18136} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48834) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSON settings max_block_size=1, output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:50:26.121588 [ 4466 ] {62f52e9f-2609-4f80-b81c-85829fe18136} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:26.180840 [ 9237 ] {50fe8911-9930-4822-bce7-9334bafcfba0} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48844) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSONEachRow settings max_block_size=1, output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:50:26.183657 [ 9237 ] {50fe8911-9930-4822-bce7-9334bafcfba0} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:26.249413 [ 9237 ] {38323c86-92cf-46d5-b0af-361c02fe1004} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48858) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSONCompact settings max_block_size=1, output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:50:26.253021 [ 9237 ] {38323c86-92cf-46d5-b0af-361c02fe1004} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:26.312869 [ 9237 ] {45ae3284-9f48-4e23-b93c-69f4c32a2c78} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48866) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSONCompactEachRow settings max_block_size=1, output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:50:26.315847 [ 9237 ] {45ae3284-9f48-4e23-b93c-69f4c32a2c78} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:26.383433 [ 9235 ] {1251bcff-a705-4869-80a9-4dcc5e38d6a1} executeQuery: Code: 36. DB::Exception: The nested column of first argument in function mapFromArrays must not contain NULLs: while executing 'FUNCTION mapFromArrays(__table1.k :: 2, __table1.v :: 0) -> mapFromArrays(__table1.k, __table1.v) Map(LowCardinality(Int32), Int32) : 1'. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50892) (comment: 03399_lc_nullable_mapfromarrays.sql) (query 18, line 55) (in query: SELECT mapFromArrays(k, v) FROM 03399_lc_nullable_int_mixed;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionMapFromArrays::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001469a700 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:50:26.387811 [ 9237 ] {0bcebd6b-8913-4591-abcc-68962a55e1c4} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48874) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSONObjectEachRow settings max_block_size=1, output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:50:26.388947 [ 9235 ] {} TCPHandler: Code: 36. DB::Exception: The nested column of first argument in function mapFromArrays must not contain NULLs: while executing 'FUNCTION mapFromArrays(__table1.k :: 2, __table1.v :: 0) -> mapFromArrays(__table1.k, __table1.v) Map(LowCardinality(Int32), Int32) : 1'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionMapFromArrays::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001469a700 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:50:26.391435 [ 9237 ] {0bcebd6b-8913-4591-abcc-68962a55e1c4} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:26.452586 [ 9237 ] {66155990-ba9d-4f32-b805-2a123c9998c1} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48882) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format XML settings max_block_size=1, output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:50:26.455402 [ 9237 ] {66155990-ba9d-4f32-b805-2a123c9998c1} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:26.509899 [ 9237 ] {b518781e-6df1-4889-ad20-daef9178ad1d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48888) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSON settings max_block_size=1, output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:50:26.514440 [ 9237 ] {b518781e-6df1-4889-ad20-daef9178ad1d} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:26.608239 [ 9235 ] {503a3c75-1611-447e-b412-1041a40cd5c4} executeQuery: Code: 36. DB::Exception: The nested column of first argument in function mapFromArrays must not contain NULLs: while executing 'FUNCTION mapFromArrays(__table1.k :: 2, __table1.v :: 0) -> mapFromArrays(__table1.k, __table1.v) Map(LowCardinality(Int32), Int32) : 1'. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50892) (comment: 03399_lc_nullable_mapfromarrays.sql) (query 19, line 56) (in query: SELECT mapFromArrays(k, v) FROM 03399_lc_nullable_int_mixed GROUP BY 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionMapFromArrays::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001469a700 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:50:26.614978 [ 9235 ] {} TCPHandler: Code: 36. DB::Exception: The nested column of first argument in function mapFromArrays must not contain NULLs: while executing 'FUNCTION mapFromArrays(__table1.k :: 2, __table1.v :: 0) -> mapFromArrays(__table1.k, __table1.v) Map(LowCardinality(Int32), Int32) : 1'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionMapFromArrays::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001469a700 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:50:27.160419 [ 9235 ] {f7b285cc-3a9c-49d6-b919-3e15777d772b} executeQuery: Code: 36. DB::Exception: The nested column of first argument in function mapFromArrays must not contain NULLs: while executing 'FUNCTION mapFromArrays(__table1.k :: 2, __table1.v :: 0) -> mapFromArrays(__table1.k, __table1.v) Map(LowCardinality(String), Int32) : 1'. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50892) (comment: 03399_lc_nullable_mapfromarrays.sql) (query 28, line 84) (in query: SELECT mapFromArrays(k, v) FROM 03399_lc_nullable_string_mixed;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionMapFromArrays::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001469a700 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:50:27.169903 [ 9235 ] {} TCPHandler: Code: 36. DB::Exception: The nested column of first argument in function mapFromArrays must not contain NULLs: while executing 'FUNCTION mapFromArrays(__table1.k :: 2, __table1.v :: 0) -> mapFromArrays(__table1.k, __table1.v) Map(LowCardinality(String), Int32) : 1'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionMapFromArrays::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001469a700 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:50:27.226660 [ 3514 ] {f40d29ad-ee6d-4604-9c28-e5a8add2b7f1} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48902) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSONCompact settings max_block_size=1, output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:50:27.234206 [ 3514 ] {f40d29ad-ee6d-4604-9c28-e5a8add2b7f1} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:27.241756 [ 9235 ] {39c690ba-d300-4bc0-a93c-e47d233b1221} executeQuery: Code: 36. DB::Exception: The nested column of first argument in function mapFromArrays must not contain NULLs: while executing 'FUNCTION mapFromArrays(__table1.k :: 2, __table1.v :: 0) -> mapFromArrays(__table1.k, __table1.v) Map(LowCardinality(String), Int32) : 1'. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50892) (comment: 03399_lc_nullable_mapfromarrays.sql) (query 29, line 85) (in query: SELECT mapFromArrays(k, v) FROM 03399_lc_nullable_string_mixed GROUP BY 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionMapFromArrays::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001469a700 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:50:27.250223 [ 9235 ] {} TCPHandler: Code: 36. DB::Exception: The nested column of first argument in function mapFromArrays must not contain NULLs: while executing 'FUNCTION mapFromArrays(__table1.k :: 2, __table1.v :: 0) -> mapFromArrays(__table1.k, __table1.v) Map(LowCardinality(String), Int32) : 1'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionMapFromArrays::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001469a700 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:50:27.948661 [ 4466 ] {85662941-66a2-4f18-b12e-7cd02aace626} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48916) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSONObjectEachRow settings max_block_size=1, output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:50:27.958233 [ 4466 ] {85662941-66a2-4f18-b12e-7cd02aace626} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:28.652972 [ 3514 ] {a27352ad-8453-430f-a227-8da982fd070d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48930) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSONEachRow settings max_block_size=1, output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:50:28.660931 [ 3514 ] {a27352ad-8453-430f-a227-8da982fd070d} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:29.354416 [ 9231 ] {1ce885a4-8944-43b9-b291-015829d1b307} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:48938) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSONCompactEachRow settings max_block_size=1, output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:50:29.361424 [ 9231 ] {1ce885a4-8944-43b9-b291-015829d1b307} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:29.938294 [ 4466 ] {8871e240-7845-4da6-aeec-c4fc9f91d953} executeQuery: Code: 43. DB::Exception: Types Array(String) and Float64 are non-conforming as arguments for aggregate function avgWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50940) (comment: 01035_avg_weighted_long.sh) (query 1, line 1) (in query: SELECT avgWeighted(['string'], toFloat64(0))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x00000000208e7837 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionAvgWeighted.cpp:176: DB::(anonymous namespace)::createAggregateFunctionAvgWeighted(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000203d590f 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000203d4b63 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d009bfb 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303855f9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 08:50:29.943462 [ 4466 ] {} TCPHandler: Code: 43. DB::Exception: Types Array(String) and Float64 are non-conforming as arguments for aggregate function avgWeighted. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x00000000208e7837 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionAvgWeighted.cpp:176: DB::(anonymous namespace)::createAggregateFunctionAvgWeighted(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000203d590f 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000203d4b63 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d009bfb 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303855f9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 08:50:35.929720 [ 1389 ] {} ExternalDictionaries: Could not update cache dictionary 'one_cell_cache_ints', next update is scheduled at 2025-06-13 08:50:41: Code: 81. DB::Exception: Database test_01054 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Interpreters/Context.cpp:5680: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000003174f585 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:161: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x0000000031022964 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035d64c 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4364: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c4340 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000026edde23 21. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:127: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x0000000026edeb60 22. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000277239f9 23. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 25. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 31. ? @ 0x00007f5206343ac3 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 32. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 33. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 34. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 35. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 36. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 37. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 38. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 39. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 40. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 41. ? @ 0x00007f5206343ac3 42. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:35.931942 [ 4786 ] {} ExternalDictionaries: Could not update cache dictionary 'one_cell_cache_ints', next update is scheduled at 2025-06-13 08:50:40: Code: 81. DB::Exception: Database test_01054 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Interpreters/Context.cpp:5680: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000003174f585 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:161: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x0000000031022964 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035d64c 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4364: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c4340 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000026edde23 21. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:127: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x0000000026edeb60 22. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000277239f9 23. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 25. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 31. ? @ 0x00007f5206343ac3 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 32. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 33. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 34. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 35. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 36. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 37. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 38. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 39. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 40. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 41. ? @ 0x00007f5206343ac3 42. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:35.933983 [ 2940 ] {} ExternalDictionaries: Could not update cache dictionary 'one_cell_cache_ints', next update is scheduled at 2025-06-13 08:50:41: Code: 81. DB::Exception: Database test_01054 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Interpreters/Context.cpp:5680: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000003174f585 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:161: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x0000000031022964 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035d64c 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4364: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c4340 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000026edde23 21. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:127: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x0000000026edeb60 22. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000277239f9 23. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 25. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 31. ? @ 0x00007f5206343ac3 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 32. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 33. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 34. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 35. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 36. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 37. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 38. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 39. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 40. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 41. ? @ 0x00007f5206343ac3 42. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:35.935590 [ 1378 ] {} ExternalDictionaries: Could not update cache dictionary 'one_cell_cache_ints', next update is scheduled at 2025-06-13 08:50:46: Code: 81. DB::Exception: Database test_01054 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Interpreters/Context.cpp:5680: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000003174f585 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:161: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x0000000031022964 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035d64c 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4364: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c4340 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000026edde23 21. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:127: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x0000000026edeb60 22. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000277239f9 23. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 25. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 31. ? @ 0x00007f5206343ac3 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 32. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 33. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 34. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 35. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 36. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 37. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 38. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 39. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 40. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 41. ? @ 0x00007f5206343ac3 42. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:36.249873 [ 2134 ] {349066f3-34f7-4e32-8204-fbbbdd344301} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Update failed for dictionary one_cell_cache_ints : Code: 81. DB::Exception: Database test_01054 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Interpreters/Context.cpp:5680: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000003174f585 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:161: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x0000000031022964 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035d64c 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4364: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c4340 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000026edde23 21. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:127: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x0000000026edeb60 22. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000277239f9 23. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 25. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 31. ? @ 0x00007f5206343ac3 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 32. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 33. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 34. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 35. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 36. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 37. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 38. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 39. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 40. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 41. ? @ 0x00007f5206343ac3 42. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(61)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52634) (comment: 01054_cache_dictionary_bunch_update.sh) (query 1, line 1) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(61));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:50:36.250177 [ 2135 ] {08c9f5d4-fdec-47c7-a35f-25d98e56af42} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Update failed for dictionary one_cell_cache_ints : Code: 81. DB::Exception: Database test_01054 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Interpreters/Context.cpp:5680: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000003174f585 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:161: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x0000000031022964 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035d64c 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4364: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c4340 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000026edde23 21. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:127: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x0000000026edeb60 22. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000277239f9 23. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 25. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 31. ? @ 0x00007f5206343ac3 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 32. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 33. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 34. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 35. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 36. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 37. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 38. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 39. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 40. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 41. ? @ 0x00007f5206343ac3 42. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(45)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52636) (comment: 01054_cache_dictionary_bunch_update.sh) (query 1, line 1) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(45));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:50:36.252221 [ 2141 ] {0738ea01-933e-48fd-8a7d-67c41a41bd00} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Update failed for dictionary one_cell_cache_ints : Code: 81. DB::Exception: Database test_01054 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Interpreters/Context.cpp:5680: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000003174f585 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:161: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x0000000031022964 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035d64c 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4364: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c4340 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000026edde23 21. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:127: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x0000000026edeb60 22. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000277239f9 23. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 25. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 31. ? @ 0x00007f5206343ac3 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 32. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 33. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 34. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 35. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 36. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 37. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 38. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 39. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 40. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 41. ? @ 0x00007f5206343ac3 42. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(12)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52632) (comment: 01054_cache_dictionary_bunch_update.sh) (query 1, line 1) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(12));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:50:36.256587 [ 2134 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Update failed for dictionary one_cell_cache_ints : Code: 81. DB::Exception: Database test_01054 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Interpreters/Context.cpp:5680: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000003174f585 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:161: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x0000000031022964 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035d64c 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4364: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c4340 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000026edde23 21. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:127: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x0000000026edeb60 22. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000277239f9 23. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 25. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 31. ? @ 0x00007f5206343ac3 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 32. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 33. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 34. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 35. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 36. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 37. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 38. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 39. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 40. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 41. ? @ 0x00007f5206343ac3 42. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(61)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:50:36.252727 [ 2085 ] {3bbe3fcc-2c17-4485-bebe-c5a557bf136d} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Update failed for dictionary one_cell_cache_ints : Code: 81. DB::Exception: Database test_01054 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Interpreters/Context.cpp:5680: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000003174f585 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:161: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x0000000031022964 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035d64c 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4364: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c4340 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000026edde23 21. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:127: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x0000000026edeb60 22. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000277239f9 23. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 25. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 31. ? @ 0x00007f5206343ac3 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 32. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 33. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 34. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 35. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 36. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 37. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 38. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 39. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 40. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 41. ? @ 0x00007f5206343ac3 42. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(81)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52630) (comment: 01054_cache_dictionary_bunch_update.sh) (query 1, line 1) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(81));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:50:36.262684 [ 2135 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Update failed for dictionary one_cell_cache_ints : Code: 81. DB::Exception: Database test_01054 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Interpreters/Context.cpp:5680: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000003174f585 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:161: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x0000000031022964 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035d64c 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4364: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c4340 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000026edde23 21. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:127: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x0000000026edeb60 22. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000277239f9 23. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 25. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 31. ? @ 0x00007f5206343ac3 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 32. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 33. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 34. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 35. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 36. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 37. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 38. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 39. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 40. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 41. ? @ 0x00007f5206343ac3 42. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(45)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:50:36.259938 [ 2141 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Update failed for dictionary one_cell_cache_ints : Code: 81. DB::Exception: Database test_01054 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Interpreters/Context.cpp:5680: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000003174f585 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:161: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x0000000031022964 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035d64c 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4364: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c4340 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000026edde23 21. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:127: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x0000000026edeb60 22. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000277239f9 23. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 25. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 31. ? @ 0x00007f5206343ac3 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 32. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 33. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 34. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 35. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 36. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 37. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 38. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 39. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 40. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 41. ? @ 0x00007f5206343ac3 42. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(12)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:50:36.267146 [ 2085 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Update failed for dictionary one_cell_cache_ints : Code: 81. DB::Exception: Database test_01054 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Interpreters/Context.cpp:5680: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000003174f585 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:161: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x0000000031022964 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035d64c 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4364: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c4340 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000026edde23 21. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:127: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x0000000026edeb60 22. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000277239f9 23. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 25. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 31. ? @ 0x00007f5206343ac3 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 32. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 33. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 34. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 35. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 36. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 37. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 38. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 39. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 40. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 41. ? @ 0x00007f5206343ac3 42. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(81)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:50:37.817318 [ 9260 ] {ace1a0e9-2369-4ecb-a323-7a205aac5778} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:50830) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 order by x format JSON settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. DB::ISerialization::serializeTextJSONPretty(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&, unsigned long) const @ 0x0000000008dcf5c0 7. ./build_docker/./src/Formats/JSONUtils.cpp:426: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af945d2 8. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:38: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4dc0e5 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 12. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:50:37.825245 [ 9260 ] {ace1a0e9-2369-4ecb-a323-7a205aac5778} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. DB::ISerialization::serializeTextJSONPretty(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&, unsigned long) const @ 0x0000000008dcf5c0 7. ./build_docker/./src/Formats/JSONUtils.cpp:426: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af945d2 8. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:38: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4dc0e5 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 12. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 9. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:37.924396 [ 9260 ] {feee5a9b-22b8-4ede-821d-e4b1c4a67673} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONEachRowRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:50842) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 order by x format JSONEachRow settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af947ba 7. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowOutputFormat.cpp:30: DB::JSONEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4cded5 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 11. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:50:37.928210 [ 9260 ] {feee5a9b-22b8-4ede-821d-e4b1c4a67673} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONEachRowRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af947ba 7. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowOutputFormat.cpp:30: DB::JSONEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4cded5 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 11. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 9. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:37.999145 [ 4332 ] {e47e56a1-6758-47ac-81e8-44d0e837c9df} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONCompactRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:50850) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 order by x format JSONCompact settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af947ba 7. ./build_docker/./src/Processors/Formats/Impl/JSONCompactRowOutputFormat.cpp:22: DB::JSONCompactRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4bf666 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 11. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:50:38.002872 [ 4332 ] {e47e56a1-6758-47ac-81e8-44d0e837c9df} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONCompactRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af947ba 7. ./build_docker/./src/Processors/Formats/Impl/JSONCompactRowOutputFormat.cpp:22: DB::JSONCompactRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4bf666 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 11. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 9. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:38.068761 [ 15837 ] {04383570-537e-4a48-acbb-b5ed5c59bc30} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-13 08:50:46. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 32. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 33. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 34. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 35. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 36. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 37. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 38. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 39. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 40. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 41. ? @ 0x00007f5206343ac3 42. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(82)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52714) (comment: 01054_cache_dictionary_bunch_update.sh) (query 1, line 1) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(82));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:50:38.070112 [ 15839 ] {8334e1fc-fad7-4d9c-a9b2-b11aad4c5f28} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONCompactEachRowRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:50864) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 order by x format JSONCompactEachRow settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. ./build_docker/./src/Processors/Formats/Impl/JSONCompactEachRowRowOutputFormat.cpp:37: DB::JSONCompactEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4b417f 7. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 8. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 10. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:50:38.073220 [ 15839 ] {8334e1fc-fad7-4d9c-a9b2-b11aad4c5f28} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONCompactEachRowRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. ./build_docker/./src/Processors/Formats/Impl/JSONCompactEachRowRowOutputFormat.cpp:37: DB::JSONCompactEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4b417f 7. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 8. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 10. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 9. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:38.080008 [ 5285 ] {c84a865e-afe3-4a15-a3ba-0daad5779f99} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-13 08:50:46. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 32. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 33. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 34. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 35. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 36. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 37. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 38. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 39. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 40. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 41. ? @ 0x00007f5206343ac3 42. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(32)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52720) (comment: 01054_cache_dictionary_bunch_update.sh) (query 1, line 1) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(32));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:50:38.080057 [ 15837 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-13 08:50:46. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 32. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 33. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 34. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 35. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 36. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 37. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 38. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 39. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 40. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 41. ? @ 0x00007f5206343ac3 42. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(82)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:50:38.079862 [ 3992 ] {272f501f-a755-470a-9606-8863bd8bf1b4} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-13 08:50:46. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 32. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 33. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 34. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 35. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 36. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 37. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 38. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 39. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 40. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 41. ? @ 0x00007f5206343ac3 42. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(37)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52728) (comment: 01054_cache_dictionary_bunch_update.sh) (query 1, line 1) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(37));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:50:38.085955 [ 5285 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-13 08:50:46. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 32. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 33. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 34. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 35. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 36. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 37. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 38. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 39. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 40. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 41. ? @ 0x00007f5206343ac3 42. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(32)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:50:38.092415 [ 3992 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-13 08:50:46. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 32. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 33. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 34. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 35. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 36. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 37. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 38. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 39. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 40. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 41. ? @ 0x00007f5206343ac3 42. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(37)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:50:38.143523 [ 15838 ] {edae57fc-5134-4032-96c5-caec2b747f97} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONObjectEachRowRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:50872) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 order by x format JSONObjectEachRow settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af947ba 7. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowOutputFormat.cpp:30: DB::JSONEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4cded5 8. ./build_docker/./src/Processors/Formats/Impl/JSONObjectEachRowRowOutputFormat.cpp:23: DB::JSONObjectEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4d5e2f 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::JSONObjectEachRowRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4d6441 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 12. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:50:38.147758 [ 15838 ] {edae57fc-5134-4032-96c5-caec2b747f97} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONObjectEachRowRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af947ba 7. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowOutputFormat.cpp:30: DB::JSONEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4cded5 8. ./build_docker/./src/Processors/Formats/Impl/JSONObjectEachRowRowOutputFormat.cpp:23: DB::JSONObjectEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4d5e2f 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::JSONObjectEachRowRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4d6441 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 12. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 9. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:38.159762 [ 4332 ] {2ea8534a-7f70-4755-a384-d4b53c70191b} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-13 08:50:46. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 32. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 33. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 34. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 35. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 36. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 37. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 38. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 39. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 40. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 41. ? @ 0x00007f5206343ac3 42. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(92)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52744) (comment: 01054_cache_dictionary_bunch_update.sh) (query 1, line 1) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(92));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:50:38.166494 [ 4332 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-13 08:50:46. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 32. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 33. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 34. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 35. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 36. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 37. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 38. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 39. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 40. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 41. ? @ 0x00007f5206343ac3 42. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(92)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:50:38.226752 [ 15838 ] {c5356c22-4249-493a-9b15-ad17b1df0233} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing XMLRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:50886) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 order by x format XML settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextXML(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f596606 6. ./build_docker/./src/Processors/Formats/Impl/XMLRowOutputFormat.cpp:79: DB::XMLRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b967737 7. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 8. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 10. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:50:38.232105 [ 15838 ] {c5356c22-4249-493a-9b15-ad17b1df0233} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing XMLRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextXML(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f596606 6. ./build_docker/./src/Processors/Formats/Impl/XMLRowOutputFormat.cpp:79: DB::XMLRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b967737 7. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 8. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 10. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 9. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:38.304181 [ 15840 ] {f7469014-5d4d-4189-8d59-feb1d51764a4} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:50896) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSON settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. DB::ISerialization::serializeTextJSONPretty(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&, unsigned long) const @ 0x0000000008dcf5c0 7. ./build_docker/./src/Formats/JSONUtils.cpp:426: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af945d2 8. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:38: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4dc0e5 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 12. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:228: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000003b5f5afc 13. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:298: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b5f9ac3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:50:38.311007 [ 15840 ] {f7469014-5d4d-4189-8d59-feb1d51764a4} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. DB::ISerialization::serializeTextJSONPretty(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&, unsigned long) const @ 0x0000000008dcf5c0 7. ./build_docker/./src/Formats/JSONUtils.cpp:426: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af945d2 8. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:38: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4dc0e5 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 12. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:228: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000003b5f5afc 13. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:298: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b5f9ac3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x000000003b5f6cb7 5. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b5f3c38 6. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:157: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x000000003b5f7ebd 7. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 9. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:39.030252 [ 15839 ] {8ea87c79-7dd6-420b-a2e9-bce61aa5e888} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:50906) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSONCompact settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af947ba 7. ./build_docker/./src/Processors/Formats/Impl/JSONCompactRowOutputFormat.cpp:22: DB::JSONCompactRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4bf666 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 11. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:228: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000003b5f5afc 12. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:298: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b5f9ac3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:50:39.035159 [ 15839 ] {8ea87c79-7dd6-420b-a2e9-bce61aa5e888} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af947ba 7. ./build_docker/./src/Processors/Formats/Impl/JSONCompactRowOutputFormat.cpp:22: DB::JSONCompactRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4bf666 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 11. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:228: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000003b5f5afc 12. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:298: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b5f9ac3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x000000003b5f6cb7 5. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b5f3c38 6. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:157: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x000000003b5f7ebd 7. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 9. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:39.706242 [ 5285 ] {e1b31c73-7e89-4775-a648-2ff8efe70ae2} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:50914) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSONObjectEachRow settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af947ba 7. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowOutputFormat.cpp:30: DB::JSONEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4cded5 8. ./build_docker/./src/Processors/Formats/Impl/JSONObjectEachRowRowOutputFormat.cpp:23: DB::JSONObjectEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4d5e2f 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::JSONObjectEachRowRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4d6441 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 12. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:228: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000003b5f5afc 13. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:298: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b5f9ac3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:50:39.712436 [ 5285 ] {e1b31c73-7e89-4775-a648-2ff8efe70ae2} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af947ba 7. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowOutputFormat.cpp:30: DB::JSONEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4cded5 8. ./build_docker/./src/Processors/Formats/Impl/JSONObjectEachRowRowOutputFormat.cpp:23: DB::JSONObjectEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4d5e2f 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::JSONObjectEachRowRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4d6441 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 12. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:228: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000003b5f5afc 13. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:298: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b5f9ac3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x000000003b5f6cb7 5. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b5f3c38 6. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:157: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x000000003b5f7ebd 7. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 9. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:39.823522 [ 4332 ] {325ea5b7-53a0-4ab8-a1f6-425d9fedd1cf} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-13 08:50:46. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 32. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 33. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 34. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 35. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 36. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 37. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 38. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 39. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 40. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 41. ? @ 0x00007f5206343ac3 42. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(24)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52814) (comment: 01054_cache_dictionary_bunch_update.sh) (query 1, line 1) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(24));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:50:39.832038 [ 4332 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-13 08:50:46. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 32. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 33. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 34. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 35. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 36. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 37. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 38. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 39. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 40. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 41. ? @ 0x00007f5206343ac3 42. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(24)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:50:39.834051 [ 15838 ] {831f316d-230e-4a87-b9bf-8999375d544b} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-13 08:50:46. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 32. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 33. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 34. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 35. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 36. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 37. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 38. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 39. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 40. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 41. ? @ 0x00007f5206343ac3 42. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(72)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52828) (comment: 01054_cache_dictionary_bunch_update.sh) (query 1, line 1) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(72));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:50:39.852710 [ 15838 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-13 08:50:46. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 32. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 33. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 34. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 35. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 36. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 37. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 38. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 39. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 40. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 41. ? @ 0x00007f5206343ac3 42. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(72)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:50:39.933422 [ 15839 ] {2604d4b1-280b-4d6d-aab2-d2c0f875446d} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-13 08:50:46. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 32. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 33. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 34. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 35. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 36. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 37. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 38. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 39. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 40. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 41. ? @ 0x00007f5206343ac3 42. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(15)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52834) (comment: 01054_cache_dictionary_bunch_update.sh) (query 1, line 1) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(15));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:50:39.941788 [ 15839 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-13 08:50:46. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 32. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 33. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 34. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 35. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 36. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 37. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 38. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 39. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 40. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 41. ? @ 0x00007f5206343ac3 42. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(15)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:50:39.979019 [ 15840 ] {1973865d-85cc-4891-b8bb-f438d6a219df} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-13 08:50:46. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 32. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 33. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 34. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 35. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 36. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 37. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 38. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 39. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 40. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 41. ? @ 0x00007f5206343ac3 42. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(59)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52850) (comment: 01054_cache_dictionary_bunch_update.sh) (query 1, line 1) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(59));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:50:39.986859 [ 15840 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-13 08:50:46. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 32. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 33. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 34. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 35. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 36. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 37. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 38. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 39. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 40. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 41. ? @ 0x00007f5206343ac3 42. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(59)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:50:40.399766 [ 15839 ] {e270ae39-c133-41ca-a39b-8b6bc072a20e} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:50916) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSONEachRow settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af947ba 7. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowOutputFormat.cpp:30: DB::JSONEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4cded5 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 11. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:228: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000003b5f5afc 12. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:298: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b5f9ac3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:50:40.406876 [ 15839 ] {e270ae39-c133-41ca-a39b-8b6bc072a20e} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af947ba 7. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowOutputFormat.cpp:30: DB::JSONEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4cded5 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 11. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:228: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000003b5f5afc 12. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:298: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b5f9ac3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x000000003b5f6cb7 5. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b5f3c38 6. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:157: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x000000003b5f7ebd 7. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 9. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:41.163972 [ 15840 ] {06852604-8eae-4e61-b134-5c300472277f} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:50930) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSONCompactEachRow settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. ./build_docker/./src/Processors/Formats/Impl/JSONCompactEachRowRowOutputFormat.cpp:37: DB::JSONCompactEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4b417f 7. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 8. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 10. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:228: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000003b5f5afc 11. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:298: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b5f9ac3 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 08:50:41.171333 [ 15840 ] {06852604-8eae-4e61-b134-5c300472277f} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. ./build_docker/./src/Processors/Formats/Impl/JSONCompactEachRowRowOutputFormat.cpp:37: DB::JSONCompactEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4b417f 7. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 8. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 10. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:228: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000003b5f5afc 11. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:298: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b5f9ac3 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x000000003b5f6cb7 5. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b5f3c38 6. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:157: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x000000003b5f7ebd 7. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 9. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:41.583293 [ 15840 ] {16d0fd67-46ea-4338-8e47-ffa63ad49d9f} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-13 08:50:46. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 32. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 33. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 34. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 35. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 36. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 37. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 38. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 39. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 40. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 41. ? @ 0x00007f5206343ac3 42. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(27)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52888) (comment: 01054_cache_dictionary_bunch_update.sh) (query 1, line 1) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(27));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:50:41.590654 [ 15840 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-13 08:50:46. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 32. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 33. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 34. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 35. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 36. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 37. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 38. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 39. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 40. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 41. ? @ 0x00007f5206343ac3 42. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(27)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:50:41.691506 [ 15844 ] {a3f02c16-08af-49f1-81fb-4ca863125687} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-13 08:50:46. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 32. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 33. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 34. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 35. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 36. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 37. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 38. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 39. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 40. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 41. ? @ 0x00007f5206343ac3 42. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(24)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52910) (comment: 01054_cache_dictionary_bunch_update.sh) (query 1, line 1) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(24));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:50:41.703841 [ 15844 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-13 08:50:46. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 32. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 33. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 34. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 35. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 36. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 37. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 38. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 39. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 40. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 41. ? @ 0x00007f5206343ac3 42. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(24)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:50:41.723472 [ 15875 ] {7e0e50fb-b30f-4c1a-a655-39f172c86fd5} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-13 08:50:46. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 32. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 33. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 34. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 35. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 36. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 37. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 38. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 39. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 40. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 41. ? @ 0x00007f5206343ac3 42. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(87)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52918) (comment: 01054_cache_dictionary_bunch_update.sh) (query 1, line 1) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(87));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:50:41.730497 [ 15875 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-13 08:50:46. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 32. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 33. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 34. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 35. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 36. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 37. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 38. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 39. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 40. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 41. ? @ 0x00007f5206343ac3 42. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(87)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:50:41.741257 [ 9234 ] {af2af3a5-75d3-4366-98e6-d69592e93351} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-13 08:50:46. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 32. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 33. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 34. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 35. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 36. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 37. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 38. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 39. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 40. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 41. ? @ 0x00007f5206343ac3 42. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(17)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52930) (comment: 01054_cache_dictionary_bunch_update.sh) (query 1, line 1) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(17));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:50:41.748087 [ 9234 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-13 08:50:46. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 32. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 33. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 34. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 35. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 36. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 37. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 38. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 39. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 40. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 41. ? @ 0x00007f5206343ac3 42. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(17)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:50:43.312082 [ 9234 ] {3551fb69-1342-4434-ad94-ca80dfddeb68} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-13 08:50:46. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 32. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 33. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 34. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 35. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 36. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 37. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 38. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 39. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 40. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 41. ? @ 0x00007f5206343ac3 42. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(13)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43436) (comment: 01054_cache_dictionary_bunch_update.sh) (query 1, line 1) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(13));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:50:43.318370 [ 9234 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-13 08:50:46. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 32. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 33. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 34. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 35. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 36. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 37. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 38. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 39. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 40. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 41. ? @ 0x00007f5206343ac3 42. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(13)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:50:43.461901 [ 15841 ] {3f9c53d1-ff9c-4825-907f-727e399f89c2} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-13 08:50:46. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 32. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 33. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 34. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 35. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 36. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 37. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 38. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 39. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 40. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 41. ? @ 0x00007f5206343ac3 42. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(1)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43448) (comment: 01054_cache_dictionary_bunch_update.sh) (query 1, line 1) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(1));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:50:43.467361 [ 15841 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-13 08:50:46. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 32. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 33. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 34. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 35. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 36. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 37. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 38. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 39. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 40. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 41. ? @ 0x00007f5206343ac3 42. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(1)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:50:43.571366 [ 15840 ] {d205a022-0400-4191-b7cf-45cef13df489} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-13 08:50:46. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 32. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 33. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 34. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 35. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 36. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 37. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 38. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 39. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 40. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 41. ? @ 0x00007f5206343ac3 42. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(15)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43454) (comment: 01054_cache_dictionary_bunch_update.sh) (query 1, line 1) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(15));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:50:43.576849 [ 15840 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-13 08:50:46. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 32. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 33. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 34. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 35. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 36. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 37. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 38. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 39. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 40. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 41. ? @ 0x00007f5206343ac3 42. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(15)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:50:43.632319 [ 2136 ] {ae0e25fb-5a75-4188-9a66-8d0d74eedc09} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-13 08:50:46. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 32. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 33. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 34. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 35. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 36. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 37. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 38. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 39. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 40. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 41. ? @ 0x00007f5206343ac3 42. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(21)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43460) (comment: 01054_cache_dictionary_bunch_update.sh) (query 1, line 1) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(21));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:50:43.639449 [ 2136 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-13 08:50:46. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 32. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 33. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 34. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 35. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 36. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 37. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 38. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 39. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 40. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 41. ? @ 0x00007f5206343ac3 42. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(21)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:50:43.754288 [ 2136 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:43460, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fbc2c6f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fbc3c01 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9b2eba 6. DB::ReadBuffer::next() @ 0x0000000008e83ccf 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003ad8c853 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:43.754758 [ 2136 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:43460, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fbc2c6f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fbc3c01 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9b2eba 6. DB::ReadBuffer::next() @ 0x0000000008e83ccf 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003ad8c853 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:46.515292 [ 9234 ] {f82cb429-6d73-4092-aecb-5bd66466c33b} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:59568) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSON settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. DB::ISerialization::serializeTextJSONPretty(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&, unsigned long) const @ 0x0000000008dcf5c0 7. ./build_docker/./src/Formats/JSONUtils.cpp:426: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af945d2 8. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:38: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4dc0e5 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 12. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:50:46.523732 [ 9234 ] {f82cb429-6d73-4092-aecb-5bd66466c33b} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. DB::ISerialization::serializeTextJSONPretty(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&, unsigned long) const @ 0x0000000008dcf5c0 7. ./build_docker/./src/Formats/JSONUtils.cpp:426: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af945d2 8. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:38: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4dc0e5 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 12. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 9. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:47.246060 [ 15840 ] {e72b2d96-0256-4e98-b3db-3b26014301a4} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:59582) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSON settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. DB::ISerialization::serializeTextJSONPretty(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&, unsigned long) const @ 0x0000000008dcf5c0 7. ./build_docker/./src/Formats/JSONUtils.cpp:426: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af945d2 8. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:38: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4dc0e5 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 12. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:228: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000003b5f5afc 13. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:298: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b5f9ac3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:50:47.260555 [ 15840 ] {e72b2d96-0256-4e98-b3db-3b26014301a4} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. DB::ISerialization::serializeTextJSONPretty(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&, unsigned long) const @ 0x0000000008dcf5c0 7. ./build_docker/./src/Formats/JSONUtils.cpp:426: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af945d2 8. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:38: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4dc0e5 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 12. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:228: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000003b5f5afc 13. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:298: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b5f9ac3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x000000003b5f6cb7 5. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b5f3c38 6. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:157: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x000000003b5f7ebd 7. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 9. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:49.041322 [ 9234 ] {bff60547-35c8-4d79-b7f6-c0c09d7fa719} executeQuery: Code: 467. DB::Exception: Cannot parse boolean value here: 'truetrue', should be 'true' or 'false' controlled by setting bool_true_representation and bool_false_representation or one of True/False/T/F/Y/N/Yes/No/On/Off/Enable/Disable/Enabled/Disabled/1/0: while executing 'FUNCTION CAST(if(modulo(__table1.number, 2_UInt8), 'truetrue'_String, _CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String)) :: 1, 'Nullable(Bool)'_String :: 4) -> CAST(if(modulo(__table1.number, 2_UInt8), 'truetrue'_String, _CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String)), 'Nullable(Bool)'_String) Nullable(Bool) : 3'. (CANNOT_PARSE_BOOL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43498) (comment: 02303_cast_nullable_to_custom_types.sql) (query 23, line 27) (in query: SELECT CAST(if(number % 2, 'truetrue', NULL), 'Nullable(Bool)') FROM numbers(2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String const&) @ 0x0000000008bb2e57 4. ./build_docker/./src/DataTypes/Serializations/SerializationBool.cpp:212: void DB::(anonymous namespace)::deserializeImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::function) @ 0x000000002f5174f5 5. ./build_docker/./src/DataTypes/Serializations/SerializationBool.cpp:449: DB::SerializationBool::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f51b494 6. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:597: DB::SerializationNullable::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f61e6ef 7. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c1f778e 8. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c1f4e39 9. bool DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c22199c 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c22152e 11. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c7d6027 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, std::shared_ptr const&, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c7d5a04 13. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:50:49.047363 [ 9234 ] {} TCPHandler: Code: 467. DB::Exception: Cannot parse boolean value here: 'truetrue', should be 'true' or 'false' controlled by setting bool_true_representation and bool_false_representation or one of True/False/T/F/Y/N/Yes/No/On/Off/Enable/Disable/Enabled/Disabled/1/0: while executing 'FUNCTION CAST(if(modulo(__table1.number, 2_UInt8), 'truetrue'_String, _CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String)) :: 1, 'Nullable(Bool)'_String :: 4) -> CAST(if(modulo(__table1.number, 2_UInt8), 'truetrue'_String, _CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String)), 'Nullable(Bool)'_String) Nullable(Bool) : 3'. (CANNOT_PARSE_BOOL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String const&) @ 0x0000000008bb2e57 4. ./build_docker/./src/DataTypes/Serializations/SerializationBool.cpp:212: void DB::(anonymous namespace)::deserializeImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::function) @ 0x000000002f5174f5 5. ./build_docker/./src/DataTypes/Serializations/SerializationBool.cpp:449: DB::SerializationBool::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f51b494 6. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:597: DB::SerializationNullable::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f61e6ef 7. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c1f778e 8. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c1f4e39 9. bool DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c22199c 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c22152e 11. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c7d6027 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, std::shared_ptr const&, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c7d5a04 13. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:50:49.117263 [ 9234 ] {9121684f-2423-47d4-9bb1-4d339cbefea7} executeQuery: Code: 467. DB::Exception: Cannot parse boolean value here: 'falsefalse', should be 'true' or 'false' controlled by setting bool_true_representation and bool_false_representation or one of True/False/T/F/Y/N/Yes/No/On/Off/Enable/Disable/Enabled/Disabled/1/0: while executing 'FUNCTION CAST(if(modulo(__table1.number, 2_UInt8), 'falsefalse'_String, _CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String)) :: 1, 'Nullable(Bool)'_String :: 4) -> CAST(if(modulo(__table1.number, 2_UInt8), 'falsefalse'_String, _CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String)), 'Nullable(Bool)'_String) Nullable(Bool) : 3'. (CANNOT_PARSE_BOOL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43498) (comment: 02303_cast_nullable_to_custom_types.sql) (query 24, line 28) (in query: SELECT CAST(if(number % 2, 'falsefalse', NULL), 'Nullable(Bool)') FROM numbers(2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String const&) @ 0x0000000008bb2e57 4. ./build_docker/./src/DataTypes/Serializations/SerializationBool.cpp:212: void DB::(anonymous namespace)::deserializeImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::function) @ 0x000000002f5174f5 5. ./build_docker/./src/DataTypes/Serializations/SerializationBool.cpp:449: DB::SerializationBool::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f51b494 6. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:597: DB::SerializationNullable::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f61e6ef 7. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c1f778e 8. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c1f4e39 9. bool DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c22199c 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c22152e 11. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c7d6027 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, std::shared_ptr const&, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c7d5a04 13. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:50:49.124244 [ 9234 ] {} TCPHandler: Code: 467. DB::Exception: Cannot parse boolean value here: 'falsefalse', should be 'true' or 'false' controlled by setting bool_true_representation and bool_false_representation or one of True/False/T/F/Y/N/Yes/No/On/Off/Enable/Disable/Enabled/Disabled/1/0: while executing 'FUNCTION CAST(if(modulo(__table1.number, 2_UInt8), 'falsefalse'_String, _CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String)) :: 1, 'Nullable(Bool)'_String :: 4) -> CAST(if(modulo(__table1.number, 2_UInt8), 'falsefalse'_String, _CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String)), 'Nullable(Bool)'_String) Nullable(Bool) : 3'. (CANNOT_PARSE_BOOL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String const&) @ 0x0000000008bb2e57 4. ./build_docker/./src/DataTypes/Serializations/SerializationBool.cpp:212: void DB::(anonymous namespace)::deserializeImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::function) @ 0x000000002f5174f5 5. ./build_docker/./src/DataTypes/Serializations/SerializationBool.cpp:449: DB::SerializationBool::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f51b494 6. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:597: DB::SerializationNullable::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f61e6ef 7. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c1f778e 8. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c1f4e39 9. bool DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c22199c 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c22152e 11. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c7d6027 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, std::shared_ptr const&, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c7d5a04 13. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:50:50.656316 [ 9234 ] {84df8623-ab0f-4f81-9491-7ee3e6f190de} executeQuery: Code: 705. DB::Exception: Table data_02716_1 is not empty. (TABLE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43540) (comment: 02716_drop_if_empty.sql) (query 11, line 16) (in query: DROP TABLE IF EMPTY data_02716_1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:154: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003296ffba 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032968e1f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965c79 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 08:50:50.659583 [ 9234 ] {} TCPHandler: Code: 705. DB::Exception: Table data_02716_1 is not empty. (TABLE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:154: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003296ffba 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032968e1f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965c79 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 08:50:50.901296 [ 9234 ] {4f7a5d62-eb6b-4a60-998b-d423bc0514e4} executeQuery: Code: 48. DB::Exception: DROP IF EMPTY is not implemented for databases. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43540) (comment: 02716_drop_if_empty.sql) (query 14, line 19) (in query: DROP DATABASE IF EMPTY test_3amau9ob_1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:408: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000003297841e 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032969430 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965ed2 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 08:50:50.904814 [ 9234 ] {} TCPHandler: Code: 48. DB::Exception: DROP IF EMPTY is not implemented for databases. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:408: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000003297841e 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032969430 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965ed2 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 08:50:53.943359 [ 15865 ] {028781a6-98ed-42ae-a5a7-2a130ca83cd3} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:36762) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSON settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. DB::ISerialization::serializeTextJSONPretty(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&, unsigned long) const @ 0x0000000008dcf5c0 7. ./build_docker/./src/Formats/JSONUtils.cpp:426: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af945d2 8. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:38: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4dc0e5 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 12. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:50:53.949794 [ 15865 ] {028781a6-98ed-42ae-a5a7-2a130ca83cd3} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. DB::ISerialization::serializeTextJSONPretty(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&, unsigned long) const @ 0x0000000008dcf5c0 7. ./build_docker/./src/Formats/JSONUtils.cpp:426: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af945d2 8. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:38: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4dc0e5 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 12. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 9. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:50:54.614990 [ 15865 ] {e80ae66c-2c70-4080-83ac-d44115683957} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:36778) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSON settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. DB::ISerialization::serializeTextJSONPretty(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&, unsigned long) const @ 0x0000000008dcf5c0 7. ./build_docker/./src/Formats/JSONUtils.cpp:426: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af945d2 8. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:38: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4dc0e5 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 12. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:228: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000003b5f5afc 13. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:298: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b5f9ac3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:50:54.622618 [ 15865 ] {e80ae66c-2c70-4080-83ac-d44115683957} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. DB::ISerialization::serializeTextJSONPretty(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&, unsigned long) const @ 0x0000000008dcf5c0 7. ./build_docker/./src/Formats/JSONUtils.cpp:426: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af945d2 8. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:38: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4dc0e5 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 12. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:228: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000003b5f5afc 13. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:298: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b5f9ac3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x000000003b5f6cb7 5. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b5f3c38 6. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:157: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x000000003b5f7ebd 7. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 9. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:51:00.617034 [ 9262 ] {e08cf946-41c9-46d3-b16c-aeeb619c615b} executeQuery: Code: 407. DB::Exception: Numeric overflow: while executing 'FUNCTION plus(toDateTime(toStartOfFifteenMinutes(plus(_CAST(1000_DateTime, 'DateTime'_String), multiply(__table2.number, 65536_UInt32)))) :: 3, multiply(__table2.number, 9223372036854775807_UInt64) :: 2) -> plus(toDateTime(toStartOfFifteenMinutes(plus(_CAST(1000_DateTime, 'DateTime'_String), multiply(__table2.number, 65536_UInt32)))), multiply(__table2.number, 9223372036854775807_UInt64)) DateTime : 0'. (DECIMAL_OVERFLOW) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38968) (comment: 02772_jit_date_time_add.sql) (query 3, line 4) (in query: SELECT DISTINCT result FROM (SELECT toStartOfFifteenMinutes(toDateTime(toStartOfFifteenMinutes(toDateTime(1000.0001220703125) + (number * 65536))) + (number * 9223372036854775807)) AS result FROM system.numbers LIMIT 1048576) ORDER BY result DESC NULLS FIRST FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000b060f13 5. void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000b05e234 6. DB::DateTimeAddIntervalImpl::execute(DB::AddSecondsImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x000000000b04b9f7 7. DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b047d57 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff69df 13. DB::FunctionBinaryArithmetic::executeDateTimeIntervalPlusMinus(std::vector> const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&) const @ 0x0000000018738afb 14. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018735fb1 15. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 21. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 27. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 08:51:00.625381 [ 9262 ] {} TCPHandler: Code: 407. DB::Exception: Numeric overflow: while executing 'FUNCTION plus(toDateTime(toStartOfFifteenMinutes(plus(_CAST(1000_DateTime, 'DateTime'_String), multiply(__table2.number, 65536_UInt32)))) :: 3, multiply(__table2.number, 9223372036854775807_UInt64) :: 2) -> plus(toDateTime(toStartOfFifteenMinutes(plus(_CAST(1000_DateTime, 'DateTime'_String), multiply(__table2.number, 65536_UInt32)))), multiply(__table2.number, 9223372036854775807_UInt64)) DateTime : 0'. (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000b060f13 5. void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000b05e234 6. DB::DateTimeAddIntervalImpl::execute(DB::AddSecondsImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x000000000b04b9f7 7. DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b047d57 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff69df 13. DB::FunctionBinaryArithmetic::executeDateTimeIntervalPlusMinus(std::vector> const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&) const @ 0x0000000018738afb 14. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018735fb1 15. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 21. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 27. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:51:02.302619 [ 4466 ] {ade7511f-c7cd-4f64-af9c-976efd08e724} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:36792) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSON settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. DB::ISerialization::serializeTextJSONPretty(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&, unsigned long) const @ 0x0000000008dcf5c0 7. ./build_docker/./src/Formats/JSONUtils.cpp:426: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af945d2 8. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:38: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4dc0e5 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 12. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:51:02.308662 [ 4466 ] {ade7511f-c7cd-4f64-af9c-976efd08e724} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. DB::ISerialization::serializeTextJSONPretty(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&, unsigned long) const @ 0x0000000008dcf5c0 7. ./build_docker/./src/Formats/JSONUtils.cpp:426: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af945d2 8. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:38: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4dc0e5 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 12. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 9. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:51:02.796793 [ 9231 ] {4db997be-8b08-49da-9d4b-415686ee17ed} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 15_UInt8) :: 0) -> throwIf(equals(__table1.number, 15_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:36808) (comment: 03174_json_compact_with_progress.sh) (in query: SELECT throwIf(number = 15), 1::Int64 as a, '"' from numbers(100) format JSONCompactEachRowWithProgress settings output_format_json_quote_64bit_integers=1, max_block_size=10), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:51:02.802884 [ 9231 ] {4db997be-8b08-49da-9d4b-415686ee17ed} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 15_UInt8) :: 0) -> throwIf(equals(__table1.number, 15_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:51:03.037089 [ 4466 ] {6a138308-2fc0-4c66-80cf-af87deb15614} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:36814) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSON settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. DB::ISerialization::serializeTextJSONPretty(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&, unsigned long) const @ 0x0000000008dcf5c0 7. ./build_docker/./src/Formats/JSONUtils.cpp:426: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af945d2 8. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:38: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4dc0e5 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 12. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:228: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000003b5f5afc 13. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:298: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b5f9ac3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:51:03.042067 [ 4466 ] {6a138308-2fc0-4c66-80cf-af87deb15614} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d09ea74 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f59554a 6. DB::ISerialization::serializeTextJSONPretty(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&, unsigned long) const @ 0x0000000008dcf5c0 7. ./build_docker/./src/Formats/JSONUtils.cpp:426: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000003af945d2 8. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:38: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b4dc0e5 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1142c5 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b4b81c9 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000003b4b791e 12. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:228: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000003b5f5afc 13. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:298: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b5f9ac3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x000000003b5f6cb7 5. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b5f3c38 6. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:157: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x000000003b5f7ebd 7. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b10e0bf 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 9. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:51:05.781353 [ 9220 ] {f66823b3-93a5-49e6-b551-c71d38e2e175} executeQuery: Code: 344. DB::Exception: FINAL modifier is not supported with parallel replicas. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36528) (comment: 02765_parallel_replicas_final_modifier.sql) (query 8, line 13) (in query: SELECT * FROM parallel_replicas_final FINAL FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Planner/Planner.cpp:1532: DB::Planner::buildPlanForQueryNode() @ 0x0000000032afb3bb 5. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 6. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 08:51:05.785167 [ 9220 ] {} TCPHandler: Code: 344. DB::Exception: FINAL modifier is not supported with parallel replicas. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Planner/Planner.cpp:1532: DB::Planner::buildPlanForQueryNode() @ 0x0000000032afb3bb 5. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 6. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 08:51:07.018168 [ 2134 ] {8ffc9f94-a68c-4a3b-acb7-b74d6221a398} executeQuery: Code: 36. DB::Exception: No such attribute 'prefixprefixprefixprefix': In scope SELECT '127.0.0.0/24' = dictGetString(concat('test_9rjs9wdq', '.dict_ipv4_trie'), 'prefixprefixprefixprefix', tuple(IPv4StringToNumOrDefault('127.0.0.0127.0.0.0'))). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36570) (comment: 01018_ip_dictionary_long.sql) (query 13, line 44) (in query: SELECT '127.0.0.0/24' = dictGetString(concat('test_9rjs9wdq', '.dict_ipv4_trie'), 'prefixprefixprefixprefix', tuple(IPv4StringToNumOrDefault('127.0.0.0127.0.0.0')))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Dictionaries/DictionaryStructure.cpp:176: DB::DictionaryStructure::getAttribute(String const&) const @ 0x000000002bfe3804 5. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009094048 6. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f9339 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 2025.06.13 08:51:07.021915 [ 2134 ] {} TCPHandler: Code: 36. DB::Exception: No such attribute 'prefixprefixprefixprefix': In scope SELECT '127.0.0.0/24' = dictGetString(concat('test_9rjs9wdq', '.dict_ipv4_trie'), 'prefixprefixprefixprefix', tuple(IPv4StringToNumOrDefault('127.0.0.0127.0.0.0'))). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Dictionaries/DictionaryStructure.cpp:176: DB::DictionaryStructure::getAttribute(String const&) const @ 0x000000002bfe3804 5. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009094048 6. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f9339 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 2025.06.13 08:51:08.022277 [ 2141 ] {01808386-97d5-4286-a0d7-d7df4a766f16} executeQuery: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36580) (comment: 02498_storage_join_key_positions.sql) (query 26, line 38) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON t1.key1 = tj.key1 AND t1.key3 = tj.key3 AND t1.key2 = tj.key2 AND 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x0000000032bf6ecd 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1236: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x0000000032bf3fe5 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003c09e07a 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x000000003c3e710a 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c3be655 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f95f8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:51:08.026564 [ 2141 ] {} TCPHandler: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x0000000032bf6ecd 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1236: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x0000000032bf3fe5 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003c09e07a 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x000000003c3e710a 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c3be655 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f95f8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:51:08.078136 [ 2141 ] {530f6d16-d2f9-4138-a2fe-c8bd8f917264} executeQuery: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36580) (comment: 02498_storage_join_key_positions.sql) (query 27, line 39) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON t1.key1 = tj.key1 AND t1.key3 = tj.key3 AND t1.key2 = tj.key2 AND 1 > 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x0000000032bf6ecd 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1236: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x0000000032bf3fe5 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003c09e07a 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x000000003c3e710a 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c3be655 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f95f8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:51:08.082430 [ 2141 ] {} TCPHandler: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x0000000032bf6ecd 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1236: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x0000000032bf3fe5 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003c09e07a 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x000000003c3e710a 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c3be655 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f95f8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:51:08.171932 [ 2141 ] {eb6130ae-1ece-4de2-bc4a-86a14026005c} executeQuery: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36580) (comment: 02498_storage_join_key_positions.sql) (query 29, line 42) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x0000000032bf6ecd 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1236: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x0000000032bf3fe5 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003c09e07a 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x000000003c3e710a 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c3be655 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f95f8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:51:08.175185 [ 2141 ] {} TCPHandler: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x0000000032bf6ecd 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1236: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x0000000032bf3fe5 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003c09e07a 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x000000003c3e710a 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c3be655 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f95f8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:51:08.214702 [ 2141 ] {ada6d081-b74a-4abf-87e5-c9e4c079445c} executeQuery: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36580) (comment: 02498_storage_join_key_positions.sql) (query 30, line 43) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x0000000032bf6ecd 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1236: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x0000000032bf3fe5 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003c09e07a 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x000000003c3e710a 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c3be655 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f95f8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:51:08.218297 [ 2141 ] {} TCPHandler: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x0000000032bf6ecd 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1236: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x0000000032bf3fe5 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003c09e07a 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x000000003c3e710a 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c3be655 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f95f8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:51:08.236900 [ 9231 ] {d9fe104a-bdd0-4781-ae30-ba9cbd76fd09} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 1 (BADREQUEST): BADREQUEST . Expected one of: Query, Query with output, EXPLAIN, EXPLAIN, SELECT query, possibly with UNION, list of union elements, SELECT query, subquery, possibly with UNION, SELECT subquery, SELECT query, WITH, FROM, SELECT, SHOW CREATE QUOTA query, SHOW CREATE, SHOW [FULL] [TEMPORARY] TABLES|DATABASES|CLUSTERS|CLUSTER|MERGES 'name' [[NOT] [I]LIKE 'str'] [LIMIT expr], SHOW, SHOW COLUMNS query, SHOW ENGINES query, SHOW ENGINES, SHOW FUNCTIONS query, SHOW FUNCTIONS, SHOW INDEXES query, SHOW SETTING query, SHOW SETTING, EXISTS or SHOW CREATE query, EXISTS, DESCRIBE FILESYSTEM CACHE query, DESCRIBE, DESC, DESCRIBE query, SHOW PROCESSLIST query, SHOW PROCESSLIST, CREATE TABLE or ATTACH TABLE query, CREATE, ATTACH, REPLACE, CREATE DATABASE query, CREATE VIEW query, CREATE DICTIONARY, CREATE LIVE VIEW query, CREATE WINDOW VIEW query, ALTER query, ALTER TABLE, ALTER TEMPORARY TABLE, ALTER DATABASE, RENAME query, RENAME DATABASE, RENAME TABLE, EXCHANGE TABLES, RENAME DICTIONARY, EXCHANGE DICTIONARIES, RENAME, DROP query, DROP, DETACH, TRUNCATE, UNDROP query, UNDROP, CHECK ALL TABLES, CHECK TABLE, KILL QUERY query, KILL, OPTIMIZE query, OPTIMIZE TABLE, WATCH query, WATCH, SHOW ACCESS query, SHOW ACCESS, ShowAccessEntitiesQuery, SHOW GRANTS query, SHOW GRANTS, SHOW PRIVILEGES query, SHOW PRIVILEGES, BACKUP or RESTORE query, BACKUP, RESTORE, INSERT query, INSERT INTO, USE query, USE, SET ROLE or SET DEFAULT ROLE query, SET ROLE DEFAULT, SET ROLE, SET DEFAULT ROLE, SET query, SET, SYSTEM query, SYSTEM, CREATE USER or ALTER USER query, ALTER USER, CREATE USER, CREATE ROLE or ALTER ROLE query, ALTER ROLE, CREATE ROLE, CREATE QUOTA or ALTER QUOTA query, ALTER QUOTA, CREATE QUOTA, CREATE ROW POLICY or ALTER ROW POLICY query, ALTER POLICY, ALTER ROW POLICY, CREATE POLICY, CREATE ROW POLICY, CREATE SETTINGS PROFILE or ALTER SETTINGS PROFILE query, ALTER SETTINGS PROFILE, ALTER PROFILE, CREATE SETTINGS PROFILE, CREATE PROFILE, CREATE FUNCTION query, DROP FUNCTION query, CREATE WORKLOAD query, DROP WORKLOAD query, CREATE RESOURCE query, DROP RESOURCE query, CREATE NAMED COLLECTION, DROP NAMED COLLECTION query, Alter NAMED COLLECTION query, ALTER, CREATE INDEX query, DROP INDEX query, DROP access entity query, MOVE access entity query, MOVE, GRANT or REVOKE query, REVOKE, GRANT, CHECK GRANT, CHECK GRANT, EXTERNAL DDL query, EXTERNAL DDL FROM, TCL query, BEGIN TRANSACTION, START TRANSACTION, COMMIT, ROLLBACK, SET TRANSACTION SNAPSHOT, Delete query, DELETE. (SYNTAX_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:46336) (comment: 01071_http_header_exception_code.sh) (in query: BADREQUEST ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008c167de 3. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003e1c5d8a 4. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003e1c5ed1 5. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033726084 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 7. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:51:08.239674 [ 9231 ] {d9fe104a-bdd0-4781-ae30-ba9cbd76fd09} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 1 (BADREQUEST): BADREQUEST . Expected one of: Query, Query with output, EXPLAIN, EXPLAIN, SELECT query, possibly with UNION, list of union elements, SELECT query, subquery, possibly with UNION, SELECT subquery, SELECT query, WITH, FROM, SELECT, SHOW CREATE QUOTA query, SHOW CREATE, SHOW [FULL] [TEMPORARY] TABLES|DATABASES|CLUSTERS|CLUSTER|MERGES 'name' [[NOT] [I]LIKE 'str'] [LIMIT expr], SHOW, SHOW COLUMNS query, SHOW ENGINES query, SHOW ENGINES, SHOW FUNCTIONS query, SHOW FUNCTIONS, SHOW INDEXES query, SHOW SETTING query, SHOW SETTING, EXISTS or SHOW CREATE query, EXISTS, DESCRIBE FILESYSTEM CACHE query, DESCRIBE, DESC, DESCRIBE query, SHOW PROCESSLIST query, SHOW PROCESSLIST, CREATE TABLE or ATTACH TABLE query, CREATE, ATTACH, REPLACE, CREATE DATABASE query, CREATE VIEW query, CREATE DICTIONARY, CREATE LIVE VIEW query, CREATE WINDOW VIEW query, ALTER query, ALTER TABLE, ALTER TEMPORARY TABLE, ALTER DATABASE, RENAME query, RENAME DATABASE, RENAME TABLE, EXCHANGE TABLES, RENAME DICTIONARY, EXCHANGE DICTIONARIES, RENAME, DROP query, DROP, DETACH, TRUNCATE, UNDROP query, UNDROP, CHECK ALL TABLES, CHECK TABLE, KILL QUERY query, KILL, OPTIMIZE query, OPTIMIZE TABLE, WATCH query, WATCH, SHOW ACCESS query, SHOW ACCESS, ShowAccessEntitiesQuery, SHOW GRANTS query, SHOW GRANTS, SHOW PRIVILEGES query, SHOW PRIVILEGES, BACKUP or RESTORE query, BACKUP, RESTORE, INSERT query, INSERT INTO, USE query, USE, SET ROLE or SET DEFAULT ROLE query, SET ROLE DEFAULT, SET ROLE, SET DEFAULT ROLE, SET query, SET, SYSTEM query, SYSTEM, CREATE USER or ALTER USER query, ALTER USER, CREATE USER, CREATE ROLE or ALTER ROLE query, ALTER ROLE, CREATE ROLE, CREATE QUOTA or ALTER QUOTA query, ALTER QUOTA, CREATE QUOTA, CREATE ROW POLICY or ALTER ROW POLICY query, ALTER POLICY, ALTER ROW POLICY, CREATE POLICY, CREATE ROW POLICY, CREATE SETTINGS PROFILE or ALTER SETTINGS PROFILE query, ALTER SETTINGS PROFILE, ALTER PROFILE, CREATE SETTINGS PROFILE, CREATE PROFILE, CREATE FUNCTION query, DROP FUNCTION query, CREATE WORKLOAD query, DROP WORKLOAD query, CREATE RESOURCE query, DROP RESOURCE query, CREATE NAMED COLLECTION, DROP NAMED COLLECTION query, Alter NAMED COLLECTION query, ALTER, CREATE INDEX query, DROP INDEX query, DROP access entity query, MOVE access entity query, MOVE, GRANT or REVOKE query, REVOKE, GRANT, CHECK GRANT, CHECK GRANT, EXTERNAL DDL query, EXTERNAL DDL FROM, TCL query, BEGIN TRANSACTION, START TRANSACTION, COMMIT, ROLLBACK, SET TRANSACTION SNAPSHOT, Delete query, DELETE. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008c167de 3. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003e1c5d8a 4. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003e1c5ed1 5. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033726084 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 7. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:51:08.254858 [ 2141 ] {b5e01fa9-5a46-4d51-8cb6-841de543ae1c} executeQuery: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36580) (comment: 02498_storage_join_key_positions.sql) (query 31, line 44) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON NULL;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x0000000032bf6ecd 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1236: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x0000000032bf3fe5 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003c09e07a 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x000000003c3e710a 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c3be655 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f95f8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:51:08.258289 [ 2141 ] {} TCPHandler: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x0000000032bf6ecd 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1236: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x0000000032bf3fe5 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003c09e07a 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x000000003c3e710a 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c3be655 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f95f8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:51:08.295067 [ 2141 ] {874f1b09-d0af-4462-851a-4bdcf5a9c4ec} executeQuery: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36580) (comment: 02498_storage_join_key_positions.sql) (query 32, line 45) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON 1 != 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x0000000032bf6ecd 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1236: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x0000000032bf3fe5 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003c09e07a 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x000000003c3e710a 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c3be655 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f95f8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:51:08.298442 [ 2141 ] {} TCPHandler: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x0000000032bf6ecd 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1236: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x0000000032bf3fe5 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003c09e07a 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x000000003c3e710a 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c3be655 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f95f8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:51:08.341041 [ 2141 ] {9f023774-17fb-4fd9-ab54-91cb8d70d539} executeQuery: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36580) (comment: 02498_storage_join_key_positions.sql) (query 33, line 47) (in query: -- Here is another error code because equality is handled differently in CollectJoinOnKeysVisitor. -- We can change the error code, but it will become inconsistent for other cases -- where we actually expect AMBIGUOUS_COLUMN_NAME instead of INVALID_JOIN_ON_EXPRESSION/INCOMPATIBLE_TYPE_OF_JOIN. -- These checks are more reliable after switching to a new analyzer, they return INCOMPATIBLE_TYPE_OF_JOIN consistent with cases above SELECT * FROM t1 ALL INNER JOIN tj ON 1 == 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x0000000032bf6ecd 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1236: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x0000000032bf3fe5 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003c09e07a 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x000000003c3e710a 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c3be655 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f95f8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:51:08.345322 [ 2141 ] {} TCPHandler: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x0000000032bf6ecd 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1236: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x0000000032bf3fe5 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003c09e07a 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x000000003c3e710a 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c3be655 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f95f8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:51:08.406656 [ 2141 ] {c2ed12c8-fee3-465d-a68e-2394726a180f} executeQuery: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36580) (comment: 02498_storage_join_key_positions.sql) (query 34, line 52) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON 1 == 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x0000000032bf6ecd 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1236: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x0000000032bf3fe5 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003c09e07a 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x000000003c3e710a 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c3be655 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f95f8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:51:08.411704 [ 2141 ] {} TCPHandler: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x0000000032bf6ecd 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1236: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x0000000032bf3fe5 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003c09e07a 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x000000003c3e710a 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c3be655 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f95f8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:51:08.470586 [ 9229 ] {1eaeee44-4a47-4d11-abf7-effb504fd23e} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of 2nd (optional) argument of function toDayOfWeek. Must be constant UInt8 (week mode).: In scope SELECT toDayOfWeek(today(), -1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36636) (comment: 02521_to_custom_day_of_week.sql) (query 8, line 10) (in query: select toDayOfWeek(today(), -1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::IFunctionCustomWeek::checkArguments(std::vector> const&, bool, bool) const @ 0x000000001a9f7cb5 5. DB::FunctionCustomWeekToSomething, DB::ToDayOfWeekImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a9f0efd 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:51:08.473981 [ 9229 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of 2nd (optional) argument of function toDayOfWeek. Must be constant UInt8 (week mode).: In scope SELECT toDayOfWeek(today(), -1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::IFunctionCustomWeek::checkArguments(std::vector> const&, bool, bool) const @ 0x000000001a9f7cb5 5. DB::FunctionCustomWeekToSomething, DB::ToDayOfWeekImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a9f0efd 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:51:08.655984 [ 2141 ] {ab6a3570-0fc4-4006-92ca-f1b0f416d657} executeQuery: Code: 47. DB::Exception: JOIN ALL INNER JOIN ... USING (key1, key2, attr) using identifier 'attr' cannot be resolved from left table expression. In scope SELECT * FROM t1 ALL INNER JOIN tj USING (key1, key2, attr). (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36580) (comment: 02498_storage_join_key_positions.sql) (query 35, line 54) (in query: SELECT * FROM t1 ALL INNER JOIN tj USING (key1, key2, attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x00000000303de19f 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5255: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303d4e1a 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f5a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:51:08.660417 [ 2141 ] {} TCPHandler: Code: 47. DB::Exception: JOIN ALL INNER JOIN ... USING (key1, key2, attr) using identifier 'attr' cannot be resolved from left table expression. In scope SELECT * FROM t1 ALL INNER JOIN tj USING (key1, key2, attr). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x00000000303de19f 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5255: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303d4e1a 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f5a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:51:08.687909 [ 2141 ] {250427b4-bf50-4b52-ad94-e7a78ef3872d} executeQuery: Code: 47. DB::Exception: JOIN ALL INNER JOIN ... USING (key1, key2, key3, attr) using identifier 'attr' cannot be resolved from left table expression. In scope SELECT * FROM t1 ALL INNER JOIN tj USING (key1, key2, key3, attr). (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36580) (comment: 02498_storage_join_key_positions.sql) (query 36, line 55) (in query: SELECT * FROM t1 ALL INNER JOIN tj USING (key1, key2, key3, attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x00000000303de19f 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5255: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303d4e1a 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f5a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:51:08.691674 [ 2141 ] {} TCPHandler: Code: 47. DB::Exception: JOIN ALL INNER JOIN ... USING (key1, key2, key3, attr) using identifier 'attr' cannot be resolved from left table expression. In scope SELECT * FROM t1 ALL INNER JOIN tj USING (key1, key2, key3, attr). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x00000000303de19f 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5255: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303d4e1a 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f5a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:51:08.884429 [ 2141 ] {f4f060fe-e4de-4a5b-8bf6-71c2183ffaf2} executeQuery: Code: 264. DB::Exception: Number of keys in JOIN ON section (2) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36580) (comment: 02498_storage_join_key_positions.sql) (query 37, line 57) (in query: SELECT * FROM t1 ALL INNER JOIN tj USING (key2, key3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x000000001f509a6d 4. ./build_docker/./src/Storages/StorageJoin.cpp:264: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x00000000384ddef8 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1244: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x0000000032bf1ece 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003c09e07a 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x000000003c3e710a 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c3be655 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f95f8 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:51:08.887883 [ 2141 ] {} TCPHandler: Code: 264. DB::Exception: Number of keys in JOIN ON section (2) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x000000001f509a6d 4. ./build_docker/./src/Storages/StorageJoin.cpp:264: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x00000000384ddef8 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1244: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x0000000032bf1ece 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003c09e07a 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x000000003c3e710a 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c3be655 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f95f8 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:51:08.928926 [ 2141 ] {62bf89da-0b42-48e7-8417-e7a4582e45c7} executeQuery: Code: 264. DB::Exception: Number of keys in JOIN ON section (1) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36580) (comment: 02498_storage_join_key_positions.sql) (query 38, line 58) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON t1.key1 = tj.attr;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x000000001f509a6d 4. ./build_docker/./src/Storages/StorageJoin.cpp:264: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x00000000384ddef8 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1244: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x0000000032bf1ece 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003c09e07a 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x000000003c3e710a 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c3be655 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f95f8 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:51:08.932682 [ 2141 ] {} TCPHandler: Code: 264. DB::Exception: Number of keys in JOIN ON section (1) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x000000001f509a6d 4. ./build_docker/./src/Storages/StorageJoin.cpp:264: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x00000000384ddef8 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1244: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x0000000032bf1ece 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003c09e07a 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x000000003c3e710a 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c3be655 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f95f8 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:51:08.987067 [ 2141 ] {9cc77521-c842-4c49-bc6b-a422b7b76944} executeQuery: Code: 264. DB::Exception: Number of keys in JOIN ON section (1) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36580) (comment: 02498_storage_join_key_positions.sql) (query 39, line 59) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON t1.key1 = tj.key1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x000000001f509a6d 4. ./build_docker/./src/Storages/StorageJoin.cpp:264: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x00000000384ddef8 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1244: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x0000000032bf1ece 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003c09e07a 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x000000003c3e710a 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c3be655 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f95f8 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:51:08.991076 [ 2141 ] {} TCPHandler: Code: 264. DB::Exception: Number of keys in JOIN ON section (1) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x000000001f509a6d 4. ./build_docker/./src/Storages/StorageJoin.cpp:264: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x00000000384ddef8 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1244: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x0000000032bf1ece 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003c09e07a 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x000000003c3e710a 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c3be655 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f95f8 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:51:09.229567 [ 2141 ] {9c31397d-1bd3-4342-8697-0419cf3839a9} executeQuery: Code: 264. DB::Exception: Key 'key3' not found in JOIN ON section. Join engine keys 'key3, key2, key1' have to be used. (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36580) (comment: 02498_storage_join_key_positions.sql) (query 40, line 60) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON t1.key1 = tj.key1 AND t1.key2 = tj.key2 AND t1.key3 = tj.attr;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity, std::__wrap_iter, char>>::type>, String const&, char const*&&, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x00000000384e6bb7 4. ./build_docker/./src/Storages/StorageJoin.cpp:288: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x00000000384ddaee 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1244: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x0000000032bf1ece 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003c09e07a 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x000000003c3e710a 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c3be655 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f95f8 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:51:09.234085 [ 2141 ] {} TCPHandler: Code: 264. DB::Exception: Key 'key3' not found in JOIN ON section. Join engine keys 'key3, key2, key1' have to be used. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity, std::__wrap_iter, char>>::type>, String const&, char const*&&, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x00000000384e6bb7 4. ./build_docker/./src/Storages/StorageJoin.cpp:288: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x00000000384ddaee 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1244: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x0000000032bf1ece 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003c09e07a 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x000000003c3e710a 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c3be655 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f95f8 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:51:09.300180 [ 2141 ] {ec19110b-5216-4be8-aecb-872294a06425} executeQuery: Code: 264. DB::Exception: Number of keys in JOIN ON section (4) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36580) (comment: 02498_storage_join_key_positions.sql) (query 41, line 61) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON t1.key1 = tj.key1 AND t1.key2 = tj.key2 AND t1.key3 = tj.key3 AND t1.key1 = tj.key1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x000000001f509a6d 4. ./build_docker/./src/Storages/StorageJoin.cpp:264: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x00000000384ddef8 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1244: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x0000000032bf1ece 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003c09e07a 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x000000003c3e710a 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c3be655 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f95f8 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:51:09.304403 [ 2141 ] {} TCPHandler: Code: 264. DB::Exception: Number of keys in JOIN ON section (4) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x000000001f509a6d 4. ./build_docker/./src/Storages/StorageJoin.cpp:264: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x00000000384ddef8 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1244: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x0000000032bf1ece 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003c09e07a 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x000000003c3e710a 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c3be655 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f95f8 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:51:12.045887 [ 410 ] {} CgroupsReader: Cannot find 'kernel' in '/sys/fs/cgroup/memory.stat' (skipped 5934 similar messages) 2025.06.13 08:51:23.373167 [ 15840 ] {863820dc-3817-420b-b1d5-d160a229ba5f} executeQuery: Code: 497. DB::Exception: test_8ghrd9zy_restricted_user_230617305: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_8ghrd9zy.dict: while executing 'FUNCTION dictGetString(__dictGetString :: 1, 'value' :: 2, key :: 0) -> dictGetString(test_8ghrd9zy.dict, 'value', key) String : 5'. (ACCESS_DENIED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41906) (comment: 02885_async_insert_access_check_for_defaults.sh) (query 1, line 1) (in query: INSERT INTO table_with_default (key) VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002e2f365b 4. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x000000002e2efb16 5. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002e2ee086 6. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002e2667f8 7. ./src/Access/ContextAccess.h:256: void DB::Context::checkAccessImpl>, std::basic_string_view>>(DB::AccessFlags const&, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000003177042f 8. ./build_docker/./src/Interpreters/Context.cpp:1755: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x00000000316d430f 9. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090977be 10. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 11. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 17. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:41: DB::ConvertingTransform::onConsume(DB::Chunk) @ 0x000000003ba0fce5 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 24. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b10197a 25. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003adbc219 26. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x000000003ad8e9f8 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:51:23.382431 [ 15840 ] {} TCPHandler: Code: 497. DB::Exception: test_8ghrd9zy_restricted_user_230617305: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_8ghrd9zy.dict: while executing 'FUNCTION dictGetString(__dictGetString :: 1, 'value' :: 2, key :: 0) -> dictGetString(test_8ghrd9zy.dict, 'value', key) String : 5'. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002e2f365b 4. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x000000002e2efb16 5. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002e2ee086 6. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002e2667f8 7. ./src/Access/ContextAccess.h:256: void DB::Context::checkAccessImpl>, std::basic_string_view>>(DB::AccessFlags const&, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000003177042f 8. ./build_docker/./src/Interpreters/Context.cpp:1755: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x00000000316d430f 9. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090977be 10. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 11. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 17. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:41: DB::ConvertingTransform::onConsume(DB::Chunk) @ 0x000000003ba0fce5 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 24. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b10197a 25. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003adbc219 26. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x000000003ad8e9f8 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:51:29.485665 [ 1693 ] {b7b77119-6302-45f6-83d2-3323440e5676} executeQuery: Code: 497. DB::Exception: test_8ghrd9zy_restricted_user_230617305: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_8ghrd9zy.dict: while executing 'FUNCTION dictGetString(__dictGetString :: 1, 'value' :: 2, key :: 0) -> dictGetString(test_8ghrd9zy.dict, 'value', key) String : 5'. (ACCESS_DENIED) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02885_async_insert_access_check_for_defaults.sh) (in query: INSERT INTO test_8ghrd9zy.table_with_default (key) FORMAT Values), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002e2f365b 4. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x000000002e2efb16 5. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002e2ee086 6. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002e2667f8 7. ./src/Access/ContextAccess.h:256: void DB::Context::checkAccessImpl>, std::basic_string_view>>(DB::AccessFlags const&, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000003177042f 8. ./build_docker/./src/Interpreters/Context.cpp:1755: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x00000000316d430f 9. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090977be 10. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 11. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 17. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:41: DB::ConvertingTransform::onConsume(DB::Chunk) @ 0x000000003ba0fce5 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 26. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:996: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000003158e44c 27. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000031598b58 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 2025.06.13 08:51:29.492136 [ 1693 ] {} AsynchronousInsertQueue: Failed insertion for query 'INSERT INTO test_8ghrd9zy.table_with_default (key) FORMAT Values': Code: 497. DB::Exception: test_8ghrd9zy_restricted_user_230617305: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_8ghrd9zy.dict: while executing 'FUNCTION dictGetString(__dictGetString :: 1, 'value' :: 2, key :: 0) -> dictGetString(test_8ghrd9zy.dict, 'value', key) String : 5'. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002e2f365b 4. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x000000002e2efb16 5. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002e2ee086 6. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002e2667f8 7. ./src/Access/ContextAccess.h:256: void DB::Context::checkAccessImpl>, std::basic_string_view>>(DB::AccessFlags const&, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000003177042f 8. ./build_docker/./src/Interpreters/Context.cpp:1755: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x00000000316d430f 9. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090977be 10. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 11. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 17. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:41: DB::ConvertingTransform::onConsume(DB::Chunk) @ 0x000000003ba0fce5 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 26. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:996: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000003158e44c 27. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000031598b58 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:51:29.495854 [ 15839 ] {5fee196a-0765-4b78-9d65-1575fd395359} executeQuery: Code: 497. DB::Exception: test_8ghrd9zy_restricted_user_230617305: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_8ghrd9zy.dict: while executing 'FUNCTION dictGetString(__dictGetString :: 1, 'value' :: 2, key :: 0) -> dictGetString(test_8ghrd9zy.dict, 'value', key) String : 5': While executing WaitForAsyncInsert. (ACCESS_DENIED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50708) (comment: 02885_async_insert_access_check_for_defaults.sh) (query 1, line 1) (in query: INSERT INTO table_with_default (key) VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002e2f365b 4. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x000000002e2efb16 5. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002e2ee086 6. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002e2667f8 7. ./src/Access/ContextAccess.h:256: void DB::Context::checkAccessImpl>, std::basic_string_view>>(DB::AccessFlags const&, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000003177042f 8. ./build_docker/./src/Interpreters/Context.cpp:1755: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x00000000316d430f 9. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090977be 10. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 11. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 17. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:41: DB::ConvertingTransform::onConsume(DB::Chunk) @ 0x000000003ba0fce5 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 26. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:996: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000003158e44c 27. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000031598b58 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 2025.06.13 08:51:29.503138 [ 15839 ] {} TCPHandler: Code: 497. DB::Exception: test_8ghrd9zy_restricted_user_230617305: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_8ghrd9zy.dict: while executing 'FUNCTION dictGetString(__dictGetString :: 1, 'value' :: 2, key :: 0) -> dictGetString(test_8ghrd9zy.dict, 'value', key) String : 5': While executing WaitForAsyncInsert. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002e2f365b 4. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x000000002e2efb16 5. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002e2ee086 6. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002e2667f8 7. ./src/Access/ContextAccess.h:256: void DB::Context::checkAccessImpl>, std::basic_string_view>>(DB::AccessFlags const&, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000003177042f 8. ./build_docker/./src/Interpreters/Context.cpp:1755: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x00000000316d430f 9. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090977be 10. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 11. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 17. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:41: DB::ConvertingTransform::onConsume(DB::Chunk) @ 0x000000003ba0fce5 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 26. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:996: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000003158e44c 27. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000031598b58 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 2025.06.13 08:51:37.519017 [ 3255 ] {61885959-b8ea-4f7a-afbb-0712fa7c3a37} executeQuery: Code: 47. DB::Exception: Identifier 't1.d' cannot be resolved from table with name test_93pcva03.t1. In scope SELECT * FROM t1 INNER JOIN s ON t1.k = s.k INNER JOIN t2 ON t2.x = t1.x WHERE t1.d >= now(). Maybe you meant: ['t1.k']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41050) (comment: 02694_wrong_identifier_shouldnt_be_accepted.sql) (query 7, line 10) (in query: SELECT * FROM t1 INNER JOIN s ON t1.k = s.k INNER JOIN t2 ON t2.x = t1.x WHERE (t1.d >= now());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x0000000031047e7f 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:601: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x0000000031030b15 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000310328cd 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1349: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000310367a3 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:852: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000031037bb4 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003103680c 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:852: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000031037bb4 10. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003103680c 11. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000031044302 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b991 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030d28a 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 2025.06.13 08:51:37.523864 [ 3255 ] {} TCPHandler: Code: 47. DB::Exception: Identifier 't1.d' cannot be resolved from table with name test_93pcva03.t1. In scope SELECT * FROM t1 INNER JOIN s ON t1.k = s.k INNER JOIN t2 ON t2.x = t1.x WHERE t1.d >= now(). Maybe you meant: ['t1.k']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x0000000031047e7f 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:601: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x0000000031030b15 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000310328cd 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1349: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000310367a3 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:852: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000031037bb4 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003103680c 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:852: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000031037bb4 10. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003103680c 11. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000031044302 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b991 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030d28a 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 2025.06.13 08:51:40.968018 [ 2142 ] {035f0ec4-1f9f-4072-be34-9c12c68d695e} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(UInt8))): In scope SELECT formatRow('RawBLOB', [[[33]], []]). (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41160) (comment: 02423_multidimensional_array_get_data_at.sql) (query 1, line 1) (in query: SELECT formatRow('RawBLOB', [[[33]], []]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Columns/ColumnArray.cpp:185: DB::ColumnArray::getDataAt(unsigned long) const @ 0x0000000036f963b1 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:23: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b8c9ebd 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1141f5 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ed7c89f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 2025.06.13 08:51:40.973632 [ 2142 ] {} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(UInt8))): In scope SELECT formatRow('RawBLOB', [[[33]], []]). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Columns/ColumnArray.cpp:185: DB::ColumnArray::getDataAt(unsigned long) const @ 0x0000000036f963b1 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:23: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b8c9ebd 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1141f5 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ed7c89f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 2025.06.13 08:51:41.001334 [ 2142 ] {7d9fc633-c298-4b97-8e29-b782430e51aa} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(Nothing))): In scope SELECT formatRow('RawBLOB', [[[]], []]). (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41160) (comment: 02423_multidimensional_array_get_data_at.sql) (query 2, line 2) (in query: SELECT formatRow('RawBLOB', [[[]], []]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Columns/ColumnArray.cpp:185: DB::ColumnArray::getDataAt(unsigned long) const @ 0x0000000036f963b1 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:23: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b8c9ebd 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1141f5 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ed7c89f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 2025.06.13 08:51:41.004819 [ 2142 ] {} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(Nothing))): In scope SELECT formatRow('RawBLOB', [[[]], []]). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Columns/ColumnArray.cpp:185: DB::ColumnArray::getDataAt(unsigned long) const @ 0x0000000036f963b1 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:23: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b8c9ebd 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1141f5 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ed7c89f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 2025.06.13 08:51:41.035389 [ 2142 ] {4c4c5c88-efe3-4f69-bc0e-ac20bac3ce2f} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(Array(Array(Array(Array(UInt8))))))): In scope SELECT formatRow('RawBLOB', [[[[[[[72, 101, 108, 108, 111]]]]]], []]). (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41160) (comment: 02423_multidimensional_array_get_data_at.sql) (query 3, line 3) (in query: SELECT formatRow('RawBLOB', [[[[[[[0x48, 0x65, 0x6c, 0x6c, 0x6f]]]]]], []]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Columns/ColumnArray.cpp:185: DB::ColumnArray::getDataAt(unsigned long) const @ 0x0000000036f963b1 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:23: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b8c9ebd 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1141f5 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ed7c89f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 2025.06.13 08:51:41.039051 [ 2142 ] {} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(Array(Array(Array(Array(UInt8))))))): In scope SELECT formatRow('RawBLOB', [[[[[[[72, 101, 108, 108, 111]]]]]], []]). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Columns/ColumnArray.cpp:185: DB::ColumnArray::getDataAt(unsigned long) const @ 0x0000000036f963b1 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:23: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b8c9ebd 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1141f5 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ed7c89f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 2025.06.13 08:51:41.071346 [ 2142 ] {c8dea808-62bd-464a-be01-216f5f7c5597} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Nothing)): In scope SELECT formatRow('RawBLOB', CAST('[]', 'Array(Array(Nothing))')). (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41160) (comment: 02423_multidimensional_array_get_data_at.sql) (query 4, line 4) (in query: SELECT formatRow('RawBLOB', []::Array(Array(Nothing)));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Columns/ColumnArray.cpp:185: DB::ColumnArray::getDataAt(unsigned long) const @ 0x0000000036f963b1 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:23: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b8c9ebd 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1141f5 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ed7c89f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 2025.06.13 08:51:41.075698 [ 2142 ] {} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Nothing)): In scope SELECT formatRow('RawBLOB', CAST('[]', 'Array(Array(Nothing))')). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Columns/ColumnArray.cpp:185: DB::ColumnArray::getDataAt(unsigned long) const @ 0x0000000036f963b1 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:23: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b8c9ebd 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1141f5 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ed7c89f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 2025.06.13 08:51:41.101756 [ 2142 ] {e9111d4f-8fce-4e36-ac27-7f5c15039eca} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(String))): In scope SELECT formatRow('RawBLOB', [[], [['Hello']]]). (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41160) (comment: 02423_multidimensional_array_get_data_at.sql) (query 5, line 5) (in query: SELECT formatRow('RawBLOB', [[], [['Hello']]]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Columns/ColumnArray.cpp:185: DB::ColumnArray::getDataAt(unsigned long) const @ 0x0000000036f963b1 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:23: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b8c9ebd 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1141f5 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ed7c89f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 2025.06.13 08:51:41.105062 [ 2142 ] {} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(String))): In scope SELECT formatRow('RawBLOB', [[], [['Hello']]]). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Columns/ColumnArray.cpp:185: DB::ColumnArray::getDataAt(unsigned long) const @ 0x0000000036f963b1 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:23: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b8c9ebd 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1141f5 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ed7c89f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 2025.06.13 08:51:41.128159 [ 2142 ] {a9e163cc-8957-4365-bf4d-be0b01ee5652} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(String))): In scope SELECT formatRow('RawBLOB', [[['World']], []]). (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41160) (comment: 02423_multidimensional_array_get_data_at.sql) (query 6, line 6) (in query: SELECT formatRow('RawBLOB', [[['World']], []]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Columns/ColumnArray.cpp:185: DB::ColumnArray::getDataAt(unsigned long) const @ 0x0000000036f963b1 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:23: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b8c9ebd 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1141f5 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ed7c89f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 2025.06.13 08:51:41.131400 [ 2142 ] {} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(String))): In scope SELECT formatRow('RawBLOB', [[['World']], []]). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Columns/ColumnArray.cpp:185: DB::ColumnArray::getDataAt(unsigned long) const @ 0x0000000036f963b1 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:23: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b8c9ebd 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1141f5 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ed7c89f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 2025.06.13 08:51:41.153404 [ 2142 ] {7886e1a8-12f6-4154-a186-e55d57ecec7b} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Array(String): In scope SELECT formatRow('RawBLOB', CAST('[]', 'Array(String)')). (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41160) (comment: 02423_multidimensional_array_get_data_at.sql) (query 7, line 7) (in query: SELECT formatRow('RawBLOB', []::Array(String));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Columns/ColumnArray.cpp:185: DB::ColumnArray::getDataAt(unsigned long) const @ 0x0000000036f963b1 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:23: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b8c9ebd 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1141f5 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ed7c89f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 2025.06.13 08:51:41.156637 [ 2142 ] {} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Array(String): In scope SELECT formatRow('RawBLOB', CAST('[]', 'Array(String)')). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Columns/ColumnArray.cpp:185: DB::ColumnArray::getDataAt(unsigned long) const @ 0x0000000036f963b1 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:23: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b8c9ebd 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b1141f5 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ed7c89f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 2025.06.13 08:51:43.995788 [ 9263 ] {2c637038-b0f7-4d20-ae0d-5148f6e74350} executeQuery: Code: 55. DB::Exception: Parametrized view can't be queried through a Merge table.: Child table: test_v66kpivj.v (efb35f24-1d7c-4bab-86e9-b6d1213a22f3). (STORAGE_REQUIRES_PARAMETER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39350) (comment: 03322_view_over_parameterized_view.sql) (query 3, line 3) (in query: select * from vv;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageMerge.cpp:670: DB::ReadFromMerge::createChildrenPlans(DB::SelectQueryInfo&) const @ 0x00000000386bfd44 5. ./build_docker/./src/Storages/StorageMerge.cpp:596: DB::ReadFromMerge::filterTablesAndCreateChildrenPlans() @ 0x00000000386ad468 6. ./build_docker/./src/Storages/StorageMerge.cpp:1624: DB::ReadFromMerge::applyFilters(DB::ActionDAGNodes) @ 0x00000000386e8de0 7. ./src/Processors/QueryPlan/SourceStepWithFilter.h:39: DB::SourceStepWithFilterBase::applyFilters() @ 0x000000003c3c4387 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyConditionAndLimit.cpp:55: DB::QueryPlanOptimizations::optimizePrimaryKeyConditionAndLimit(std::vector> const&) @ 0x000000003c3c3c2a 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:125: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c3be046 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f95f8 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 2025.06.13 08:51:43.999345 [ 9263 ] {} TCPHandler: Code: 55. DB::Exception: Parametrized view can't be queried through a Merge table.: Child table: test_v66kpivj.v (efb35f24-1d7c-4bab-86e9-b6d1213a22f3). (STORAGE_REQUIRES_PARAMETER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageMerge.cpp:670: DB::ReadFromMerge::createChildrenPlans(DB::SelectQueryInfo&) const @ 0x00000000386bfd44 5. ./build_docker/./src/Storages/StorageMerge.cpp:596: DB::ReadFromMerge::filterTablesAndCreateChildrenPlans() @ 0x00000000386ad468 6. ./build_docker/./src/Storages/StorageMerge.cpp:1624: DB::ReadFromMerge::applyFilters(DB::ActionDAGNodes) @ 0x00000000386e8de0 7. ./src/Processors/QueryPlan/SourceStepWithFilter.h:39: DB::SourceStepWithFilterBase::applyFilters() @ 0x000000003c3c4387 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyConditionAndLimit.cpp:55: DB::QueryPlanOptimizations::optimizePrimaryKeyConditionAndLimit(std::vector> const&) @ 0x000000003c3c3c2a 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:125: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c3be046 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f95f8 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 2025.06.13 08:51:58.443602 [ 15838 ] {39da98ea-f38f-411f-bfa4-b6419381d1b1} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Object('json')' because experimental Object type is not allowed. Set setting allow_experimental_object_type = 1 in order to allow it: In scope SELECT CAST('{"x" : 1}', 'Object(\'json\')'). (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46422) (comment: 02513_validate_data_types.sql) (query 2, line 4) (in query: select CAST('{"x" : 1}', 'Object(''json'')');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:79: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x00000000338379aa 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x000000003383585b 6. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002c194df5 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7eb0 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:51:58.447782 [ 15838 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Object('json')' because experimental Object type is not allowed. Set setting allow_experimental_object_type = 1 in order to allow it: In scope SELECT CAST('{"x" : 1}', 'Object(\'json\')'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:79: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x00000000338379aa 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x000000003383585b 6. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002c194df5 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7eb0 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:51:58.471866 [ 15839 ] {012f23d9-6b23-4c91-bd9f-ad7d0177aad7} executeQuery: Code: 70. DB::Exception: Cannot convert NULL to a non-nullable type: while converting source column src to destination column val. (CANNOT_CONVERT_TYPE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46452) (comment: 00690_insert_select_converting_exception_message.sh) (query 1, line 1) (in query: INSERT INTO test_00690 SELECT NULL AS src SETTINGS insert_null_as_default=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c1c0559 5. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x000000002c1beb05 6. ./build_docker/./src/Interpreters/ActionsDAG.cpp:403: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x00000000300e5a29 7. ./build_docker/./src/Interpreters/ActionsDAG.cpp:362: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x00000000300e8c90 8. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1637: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000030127cb3 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:620: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000329d981e 10. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x00000000329e3a29 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:51:58.475969 [ 15839 ] {} TCPHandler: Code: 70. DB::Exception: Cannot convert NULL to a non-nullable type: while converting source column src to destination column val. (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c1c0559 5. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x000000002c1beb05 6. ./build_docker/./src/Interpreters/ActionsDAG.cpp:403: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x00000000300e5a29 7. ./build_docker/./src/Interpreters/ActionsDAG.cpp:362: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x00000000300e8c90 8. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1637: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000030127cb3 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:620: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000329d981e 10. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x00000000329e3a29 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:51:58.598332 [ 15838 ] {6b5003ad-7d31-48bc-ae3e-2627722fb870} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Object('json')' because experimental Object type is not allowed. Set setting allow_experimental_object_type = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46422) (comment: 02513_validate_data_types.sql) (query 3, line 5) (in query: desc file(nonexist.json, JSONEachRow, 'x Object(''json'')');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:79: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x00000000338379aa 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::parseColumnsListFromString(String const&, std::shared_ptr const&) @ 0x00000000338392bb 6. ./build_docker/./src/TableFunctions/TableFunctionFile.cpp:122: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002660a254 7. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x00000000338721cc 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x000000003386e605 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:51:58.602052 [ 15838 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Object('json')' because experimental Object type is not allowed. Set setting allow_experimental_object_type = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:79: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x00000000338379aa 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::parseColumnsListFromString(String const&, std::shared_ptr const&) @ 0x00000000338392bb 6. ./build_docker/./src/TableFunctions/TableFunctionFile.cpp:122: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002660a254 7. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x00000000338721cc 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x000000003386e605 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:51:58.902265 [ 15838 ] {c939507c-f74c-496e-8641-603223a62b43} executeQuery: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the `allow_suspicious_low_cardinality_types` setting: In scope SELECT CAST(1000000, 'LowCardinality(UInt64)'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46422) (comment: 02513_validate_data_types.sql) (query 5, line 8) (in query: select CAST(1000000, 'LowCardinality(UInt64)');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003383834c 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x000000003383585b 6. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002c194df5 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7eb0 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:51:58.906465 [ 15838 ] {} TCPHandler: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the `allow_suspicious_low_cardinality_types` setting: In scope SELECT CAST(1000000, 'LowCardinality(UInt64)'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003383834c 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x000000003383585b 6. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002c194df5 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7eb0 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:51:59.066571 [ 15838 ] {4d988891-21c7-433a-859e-d05dffb96b4b} executeQuery: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the `allow_suspicious_low_cardinality_types` setting. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46422) (comment: 02513_validate_data_types.sql) (query 6, line 9) (in query: desc file(nonexist.json, JSONEachRow, 'lc LowCardinality(UInt64)');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003383834c 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::parseColumnsListFromString(String const&, std::shared_ptr const&) @ 0x00000000338392bb 6. ./build_docker/./src/TableFunctions/TableFunctionFile.cpp:122: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002660a254 7. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x00000000338721cc 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x000000003386e605 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:51:59.070376 [ 15838 ] {} TCPHandler: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the `allow_suspicious_low_cardinality_types` setting. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003383834c 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::parseColumnsListFromString(String const&, std::shared_ptr const&) @ 0x00000000338392bb 6. ./build_docker/./src/TableFunctions/TableFunctionFile.cpp:122: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002660a254 7. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x00000000338721cc 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x000000003386e605 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:51:59.378239 [ 15838 ] {f93b7b7b-d190-44f4-b889-d828c2c24886} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it: In scope SELECT CAST('', 'FixedString(1000)'). (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46422) (comment: 02513_validate_data_types.sql) (query 8, line 12) (in query: select CAST('', 'FixedString(1000)');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000982248d 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000033837f73 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x000000003383585b 6. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002c194df5 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7eb0 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:51:59.381912 [ 15838 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it: In scope SELECT CAST('', 'FixedString(1000)'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000982248d 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000033837f73 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x000000003383585b 6. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002c194df5 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7eb0 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:51:59.496090 [ 15862 ] {8eebc05b-72f8-4a61-8778-32eda6867923} executeQuery: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: while converting source column src to destination column val: while executing 'FUNCTION _CAST(src :: 0, Int64 :: 1) -> _CAST(src, Int64) Int64 : 2'. (CANNOT_INSERT_NULL_IN_ORDINARY_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46496) (comment: 00690_insert_select_converting_exception_message.sh) (query 1, line 1) (in query: INSERT INTO test_00690 SELECT number % 2 ? 1 : NULL AS src FROM numbers(10) SETTINGS insert_null_as_default=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda0'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c7d7c74 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, std::shared_ptr const&, bool) const::'lambda0'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c7d7504 6. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 12. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 2025.06.13 08:51:59.523021 [ 15838 ] {fb6fd2fd-c519-49ff-9c3e-ac7b2acc1709} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46422) (comment: 02513_validate_data_types.sql) (query 9, line 13) (in query: desc file(nonexist.json, JSONEachRow, 'fs FixedString(1000)');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000982248d 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000033837f73 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::parseColumnsListFromString(String const&, std::shared_ptr const&) @ 0x00000000338392bb 6. ./build_docker/./src/TableFunctions/TableFunctionFile.cpp:122: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002660a254 7. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x00000000338721cc 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x000000003386e605 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:51:59.526451 [ 15838 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000982248d 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000033837f73 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::parseColumnsListFromString(String const&, std::shared_ptr const&) @ 0x00000000338392bb 6. ./build_docker/./src/TableFunctions/TableFunctionFile.cpp:122: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002660a254 7. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x00000000338721cc 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x000000003386e605 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:51:59.539364 [ 15862 ] {} TCPHandler: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: while converting source column src to destination column val: while executing 'FUNCTION _CAST(src :: 0, Int64 :: 1) -> _CAST(src, Int64) Int64 : 2'. (CANNOT_INSERT_NULL_IN_ORDINARY_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda0'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c7d7c74 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, std::shared_ptr const&, bool) const::'lambda0'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c7d7504 6. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 12. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 08:52:02.216715 [ 15840 ] {2287a0cf-aee5-47e6-8cad-e4b0940fa777} executeQuery: Code: 153. DB::Exception: Division of minimal signed number by minus one: In scope SELECT intDiv(-9223372036854775808, 18446744073709551615). (ILLEGAL_DIVISION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46630) (comment: 01350_intdiv_nontrivial_fpe.sql) (query 4, line 4) (in query: select intDiv(-9223372036854775808, 18446744073709551615);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. void DB::throwIfDivisionLeadsToFPE(long, long) @ 0x000000000d2d39e1 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000011e9c53d 6. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeNumber>(auto const&, auto const&) const @ 0x0000000011e9b410 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000011e93b49 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000011cf013f 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000011ce5ef2 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011ce04ad 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011cdd76d 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 2025.06.13 08:52:02.220271 [ 15840 ] {} TCPHandler: Code: 153. DB::Exception: Division of minimal signed number by minus one: In scope SELECT intDiv(-9223372036854775808, 18446744073709551615). (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. void DB::throwIfDivisionLeadsToFPE(long, long) @ 0x000000000d2d39e1 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000011e9c53d 6. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeNumber>(auto const&, auto const&) const @ 0x0000000011e9b410 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000011e93b49 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000011cf013f 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000011ce5ef2 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011ce04ad 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011cdd76d 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 2025.06.13 08:52:02.517478 [ 15840 ] {00fa3f7e-eaeb-4f9e-9af1-b232e14fcbb8} executeQuery: Code: 153. DB::Exception: Division of minimal signed number by minus one: In scope SELECT intDiv(-9223372036854775808, -1). (ILLEGAL_DIVISION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46630) (comment: 01350_intdiv_nontrivial_fpe.sql) (query 5, line 5) (in query: select intDiv(-9223372036854775808, -1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. void DB::throwIfDivisionLeadsToFPE(long, long) @ 0x000000000d2d39e1 5. COW::immutable_ptr> DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber<_BitInt(8)>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber<_BitInt(8)> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000011ea2b68 6. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeNumber<_BitInt(8)>>(auto const&, auto const&) const @ 0x0000000011ea1a10 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000011e93de9 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000011cf013f 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000011ce5ef2 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011ce04ad 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011cdd76d 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 2025.06.13 08:52:02.522016 [ 15840 ] {} TCPHandler: Code: 153. DB::Exception: Division of minimal signed number by minus one: In scope SELECT intDiv(-9223372036854775808, -1). (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. void DB::throwIfDivisionLeadsToFPE(long, long) @ 0x000000000d2d39e1 5. COW::immutable_ptr> DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber<_BitInt(8)>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber<_BitInt(8)> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000011ea2b68 6. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeNumber<_BitInt(8)>>(auto const&, auto const&) const @ 0x0000000011ea1a10 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000011e93de9 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000011cf013f 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000011ce5ef2 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011ce04ad 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011cdd76d 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 2025.06.13 08:52:04.034882 [ 15844 ] {4b73833c-625b-4574-a8f8-40985ba281c6} executeQuery: Code: 452. DB::Exception: Setting `min_rows_to_keep` cannot be higher than the `max_rows_to_keep`. `min_rows_to_keep`: 100, `max_rows_to_keep`: 0. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46620) (comment: 03009_storage_memory_circ_buffer_usage.sql) (query 36, line 60) (in query: CREATE TABLE faulty_memory (i UInt32) ENGINE = Memory SETTINGS min_rows_to_keep = 100;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b1188ad 4. ./build_docker/./src/Storages/MemorySettings.cpp:102: DB::MemorySettings::sanityCheck() const @ 0x00000000382b1d90 5. ./build_docker/./src/Storages/StorageMemory.cpp:641: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003867ae49 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:52:04.038692 [ 15844 ] {} TCPHandler: Code: 452. DB::Exception: Setting `min_rows_to_keep` cannot be higher than the `max_rows_to_keep`. `min_rows_to_keep`: 100, `max_rows_to_keep`: 0. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b1188ad 4. ./build_docker/./src/Storages/MemorySettings.cpp:102: DB::MemorySettings::sanityCheck() const @ 0x00000000382b1d90 5. ./build_docker/./src/Storages/StorageMemory.cpp:641: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003867ae49 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:52:04.242112 [ 15844 ] {505a89c3-ad29-4966-add9-161b957488ae} executeQuery: Code: 452. DB::Exception: Setting `min_bytes_to_keep` cannot be higher than the `max_bytes_to_keep`. `min_bytes_to_keep`: 100, `max_bytes_to_keep`: 0. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46620) (comment: 03009_storage_memory_circ_buffer_usage.sql) (query 37, line 61) (in query: CREATE TABLE faulty_memory (i UInt32) ENGINE = Memory SETTINGS min_bytes_to_keep = 100;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b1188ad 4. ./build_docker/./src/Storages/MemorySettings.cpp:94: DB::MemorySettings::sanityCheck() const @ 0x00000000382b1c42 5. ./build_docker/./src/Storages/StorageMemory.cpp:641: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003867ae49 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:52:04.245784 [ 15844 ] {} TCPHandler: Code: 452. DB::Exception: Setting `min_bytes_to_keep` cannot be higher than the `max_bytes_to_keep`. `min_bytes_to_keep`: 100, `max_bytes_to_keep`: 0. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b1188ad 4. ./build_docker/./src/Storages/MemorySettings.cpp:94: DB::MemorySettings::sanityCheck() const @ 0x00000000382b1c42 5. ./build_docker/./src/Storages/StorageMemory.cpp:641: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003867ae49 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:52:11.309426 [ 2133 ] {6ff0b41b-ce50-464f-8cbd-bd534dd36fe8} PushingToViews: Failed to push block to view test_3jaoymxt.mv_table (ad392224-cee0-4916-a519-ed138d04e638), ReplicatedMergeTree (table test_3jaoymxt.`.inner_id.ad392224-cee0-4916-a519-ed138d04e638` (f934c3b5-3f2f-4d52-87ec-a9ea948d58ad)) does not support transactions 2025.06.13 08:52:11.472072 [ 2133 ] {6ff0b41b-ce50-464f-8cbd-bd534dd36fe8} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_3jaoymxt.`.inner_id.ad392224-cee0-4916-a519-ed138d04e638` (f934c3b5-3f2f-4d52-87ec-a9ea948d58ad)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55290) (comment: 03167_transactions_are_really_disabled.sql) (query 7, line 10) (in query: INSERT INTO null_table VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000328b61db 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:328: DB::InterpreterInsertQuery::buildChain(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::vector> const&, std::shared_ptr, std::atomic*, bool) @ 0x00000000329cdf6d 6. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:376: DB::generateViewChain(std::shared_ptr, unsigned long, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x000000003bc5e4bd 7. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:530: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003bc68d8d 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x00000000329cff8b 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x00000000329d5483 10. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:755: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000329ddc03 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x00000000329e3913 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:52:11.475345 [ 2133 ] {} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_3jaoymxt.`.inner_id.ad392224-cee0-4916-a519-ed138d04e638` (f934c3b5-3f2f-4d52-87ec-a9ea948d58ad)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000328b61db 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:328: DB::InterpreterInsertQuery::buildChain(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::vector> const&, std::shared_ptr, std::atomic*, bool) @ 0x00000000329cdf6d 6. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:376: DB::generateViewChain(std::shared_ptr, unsigned long, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x000000003bc5e4bd 7. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:530: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003bc68d8d 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x00000000329cff8b 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x00000000329d5483 10. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:755: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000329ddc03 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x00000000329e3913 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:52:17.967419 [ 9224 ] {f865c438-6c9c-4df8-a913-80537939f958} executeQuery: Code: 25. DB::Exception: Invalid escape sequence at the end of LIKE pattern 'pattern\': while executing 'FUNCTION like(__table1.haystack :: 2, 'pattern\\'_String :: 1) -> like(__table1.haystack, 'pattern\\'_String) UInt8 : 0'. (CANNOT_PARSE_ESCAPE_SEQUENCE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53522) (comment: 02317_like_with_trailing_escape.sql) (query 4, line 7) (in query: -- const pattern SELECT haystack LIKE 'pattern\\' from tab;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000115e1d0a 4. ./build_docker/./src/Common/likePatternToRegexp.cpp:61: DB::likePatternToRegexp(std::basic_string_view>) @ 0x000000001f8605b5 5. DB::MatchImpl::vectorConstant(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, String const&, COW::immutable_ptr const&, DB::PODArray, 63ul, 64ul>&, DB::ColumnVector*, unsigned long) @ 0x000000001461cceb 6. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000146155bb 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 2025.06.13 08:52:17.974548 [ 9224 ] {} TCPHandler: Code: 25. DB::Exception: Invalid escape sequence at the end of LIKE pattern 'pattern\': while executing 'FUNCTION like(__table1.haystack :: 2, 'pattern\\'_String :: 1) -> like(__table1.haystack, 'pattern\\'_String) UInt8 : 0'. (CANNOT_PARSE_ESCAPE_SEQUENCE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000115e1d0a 4. ./build_docker/./src/Common/likePatternToRegexp.cpp:61: DB::likePatternToRegexp(std::basic_string_view>) @ 0x000000001f8605b5 5. DB::MatchImpl::vectorConstant(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, String const&, COW::immutable_ptr const&, DB::PODArray, 63ul, 64ul>&, DB::ColumnVector*, unsigned long) @ 0x000000001461cceb 6. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000146155bb 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:52:18.239760 [ 9224 ] {3b55d9a7-29b2-410a-9626-19abfff537ed} executeQuery: Code: 25. DB::Exception: Invalid escape sequence at the end of LIKE pattern 'pattern\': while executing 'FUNCTION like(__table1.haystack :: 2, __table1.pattern :: 0) -> like(__table1.haystack, __table1.pattern) UInt8 : 1'. (CANNOT_PARSE_ESCAPE_SEQUENCE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53522) (comment: 02317_like_with_trailing_escape.sql) (query 5, line 10) (in query: -- non-const pattern SELECT haystack LIKE pattern from tab;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000115e1d0a 4. ./build_docker/./src/Common/likePatternToRegexp.cpp:61: DB::likePatternToRegexp(std::basic_string_view>) @ 0x000000001f8605b5 5. OptimizedRegularExpression DB::Regexps::createRegexp(String const&) @ 0x0000000014624b06 6. std::shared_ptr DB::Regexps::LocalCacheTable::getOrSet(String const&) @ 0x00000000146223c5 7. DB::MatchImpl::vectorVector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, COW::immutable_ptr const&, DB::PODArray, 63ul, 64ul>&, DB::ColumnVector*, unsigned long) @ 0x000000001461ade0 8. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000146153e4 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 15. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 16. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 21. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:52:18.245764 [ 9224 ] {} TCPHandler: Code: 25. DB::Exception: Invalid escape sequence at the end of LIKE pattern 'pattern\': while executing 'FUNCTION like(__table1.haystack :: 2, __table1.pattern :: 0) -> like(__table1.haystack, __table1.pattern) UInt8 : 1'. (CANNOT_PARSE_ESCAPE_SEQUENCE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000115e1d0a 4. ./build_docker/./src/Common/likePatternToRegexp.cpp:61: DB::likePatternToRegexp(std::basic_string_view>) @ 0x000000001f8605b5 5. OptimizedRegularExpression DB::Regexps::createRegexp(String const&) @ 0x0000000014624b06 6. std::shared_ptr DB::Regexps::LocalCacheTable::getOrSet(String const&) @ 0x00000000146223c5 7. DB::MatchImpl::vectorVector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, COW::immutable_ptr const&, DB::PODArray, 63ul, 64ul>&, DB::ColumnVector*, unsigned long) @ 0x000000001461ade0 8. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000146153e4 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 15. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 16. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 21. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:52:23.993889 [ 9260 ] {4766fcbc-1550-4c3d-843e-7d21906b9298} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected '(' at end of stream.: while converting '' to Tuple(UInt8): In scope SELECT tuple(1) < ''. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41142) (comment: 01329_compare_tuple_string_constant.sql) (query 1, line 1) (in query: SELECT tuple(1) < '';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000001f88b188 4. ./src/IO/ReadHelpers.h:204: void DB::SerializationTuple::deserializeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x000000002f7419b6 5. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:225: DB::SerializationTuple::deserializeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x000000002f733ca9 6. DB::SimpleTextSerialization::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000008dcf546 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:578: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000033680634 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000003367a53e 9. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x00000000132fe7e7 10. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000132b4fd4 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:52:23.997701 [ 9260 ] {} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected '(' at end of stream.: while converting '' to Tuple(UInt8): In scope SELECT tuple(1) < ''. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000001f88b188 4. ./src/IO/ReadHelpers.h:204: void DB::SerializationTuple::deserializeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x000000002f7419b6 5. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:225: DB::SerializationTuple::deserializeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x000000002f733ca9 6. DB::SimpleTextSerialization::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000008dcf546 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:578: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000033680634 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000003367a53e 9. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x00000000132fe7e7 10. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000132b4fd4 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:52:24.342355 [ 9260 ] {d129780e-2ed8-42e2-8334-d52281fd5224} executeQuery: Code: 386. DB::Exception: There is no supertype for types Tuple(UInt8), String because some of them are Tuple and some of them are not. (NO_COMMON_TYPE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41142) (comment: 01329_compare_tuple_string_constant.sql) (query 2, line 2) (in query: SELECT tuple(1) < materialize('');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f4977a2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:401: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f4a5f80 5. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x0000000013304000 6. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000132b6d9c 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301087b6 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000030104ffd 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003ba0ea77 15. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003bfff312 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032b1845f 17. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x0000000032b01504 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 29. ? @ 0x00007f5206343ac3 30. ? @ 0x00007f52063d5850 2025.06.13 08:52:24.346903 [ 9260 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Tuple(UInt8), String because some of them are Tuple and some of them are not. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f4977a2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:401: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f4a5f80 5. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x0000000013304000 6. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000132b6d9c 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301087b6 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000030104ffd 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003ba0ea77 15. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003bfff312 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032b1845f 17. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x0000000032b01504 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 29. ? @ 0x00007f5206343ac3 30. ? @ 0x00007f52063d5850 2025.06.13 08:52:25.561447 [ 471 ] {} test_9hzdkbr8.rmt2 (d8a53e6b-5e26-4f55-a9cc-70232775e149): Metadata version (2) on replica is not up to date with metadata (1) on source replica 1 2025.06.13 08:52:25.682819 [ 1060 ] {} test_9hzdkbr8.rmt2 (d8a53e6b-5e26-4f55-a9cc-70232775e149): Attempt to update metadata of version 2 to older version 1 when processing log entry queue-0000000000: format version: 4 create_time: 2025-06-13 08:52:25 source replica: 1 block_id: alter alter_version 1 have_mutation 0 columns_str_size: 69 columns format version: 1 3 columns: `n` Int32 `m` Int32 `k` UInt128 metadata_str_size: 225 metadata format version: 1 date column: sampling expression: index granularity: 31876 mode: 0 sign column: primary key: data format version: 1 partition key: granularity bytes: 6373340 merge parameters format version: 2 2025.06.13 08:52:26.069041 [ 15839 ] {50f777c3-fc8a-4149-a63e-18b9dee73ec2} executeQuery: Code: 215. DB::Exception: Column test_bo2v0ayh.uk_price_paid.price is not under aggregate function and not in GROUP BY keys. In query SELECT count(), quantile(0.9)(price) OVER () AS price_quantile FROM uk_price_paid WHERE toYear(date) = 2023 QUALIFY price > price_quantile. (NOT_AN_AGGREGATE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41202) (comment: 03143_window_functions_qualify_validation.sql) (query 3, line 22) (in query: SELECT count(), (quantile(0.9)(price) OVER ()) AS price_quantile FROM uk_price_paid WHERE toYear(date) = 2023 QUALIFY price > price_quantile;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003045fcb7 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003045ed4c 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003045ed4c 7. ./build_docker/./src/Analyzer/ValidationUtils.cpp:351: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000003045d1b9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000030310e11 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:52:26.073213 [ 15839 ] {} TCPHandler: Code: 215. DB::Exception: Column test_bo2v0ayh.uk_price_paid.price is not under aggregate function and not in GROUP BY keys. In query SELECT count(), quantile(0.9)(price) OVER () AS price_quantile FROM uk_price_paid WHERE toYear(date) = 2023 QUALIFY price > price_quantile. (NOT_AN_AGGREGATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003045fcb7 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003045ed4c 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003045ed4c 7. ./build_docker/./src/Analyzer/ValidationUtils.cpp:351: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000003045d1b9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000030310e11 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:52:26.104400 [ 15875 ] {7376356b-fa5e-4f21-9bec-815c0f8e876a} executeQuery: Code: 43. DB::Exception: Illegal type Float64 of argument 1 of function s2CapUnion. Must be UInt64: In scope SELECT s2CapUnion(nan, 3.14, 1157339245694594829, 3.14). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41188) (comment: 01854_s2_cap_union.sql) (query 4, line 9) (in query: select s2CapUnion(nan, 3.14, 1157339245694594829, 3.14);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000008bd1817 4. DB::(anonymous namespace)::FunctionS2CapUnion::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a355b92 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:52:26.108483 [ 15875 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Float64 of argument 1 of function s2CapUnion. Must be UInt64: In scope SELECT s2CapUnion(nan, 3.14, 1157339245694594829, 3.14). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000008bd1817 4. DB::(anonymous namespace)::FunctionS2CapUnion::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a355b92 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:52:26.109841 [ 15839 ] {83af3731-9417-4004-bc1b-210442f73a18} executeQuery: Code: 215. DB::Exception: Column test_bo2v0ayh.uk_price_paid.price is not under aggregate function and not in GROUP BY keys. In query SELECT count() FROM uk_price_paid WHERE toYear(date) = 2023 QUALIFY price > quantile(0.9)(price) OVER (). (NOT_AN_AGGREGATE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41202) (comment: 03143_window_functions_qualify_validation.sql) (query 4, line 24) (in query: SELECT count() FROM uk_price_paid WHERE toYear(date) = 2023 QUALIFY price > (quantile(0.9)(price) OVER ());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003045fcb7 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003045ed4c 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003045ed4c 7. ./build_docker/./src/Analyzer/ValidationUtils.cpp:351: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000003045d1b9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000030310e11 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:52:26.113833 [ 15839 ] {} TCPHandler: Code: 215. DB::Exception: Column test_bo2v0ayh.uk_price_paid.price is not under aggregate function and not in GROUP BY keys. In query SELECT count() FROM uk_price_paid WHERE toYear(date) = 2023 QUALIFY price > quantile(0.9)(price) OVER (). (NOT_AN_AGGREGATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003045fcb7 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003045ed4c 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003045ed4c 7. ./build_docker/./src/Analyzer/ValidationUtils.cpp:351: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000003045d1b9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000030310e11 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:52:26.375546 [ 15875 ] {9ff0af91-e8a0-494b-b179-a7047cee7d1d} executeQuery: Code: 43. DB::Exception: Radius of the cap must not be nan: In scope SELECT s2CapUnion(1157339245694594829, nan, 1157339245694594829, 3.14). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41188) (comment: 01854_s2_cap_union.sql) (query 5, line 10) (in query: select s2CapUnion(1157339245694594829, nan, 1157339245694594829, 3.14);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::(anonymous namespace)::FunctionS2CapUnion::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a353cf8 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 08:52:26.379065 [ 15875 ] {} TCPHandler: Code: 43. DB::Exception: Radius of the cap must not be nan: In scope SELECT s2CapUnion(1157339245694594829, nan, 1157339245694594829, 3.14). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::(anonymous namespace)::FunctionS2CapUnion::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a353cf8 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 08:52:26.399122 [ 15875 ] {81e313e8-f363-4874-822f-79a77b105f3f} executeQuery: Code: 43. DB::Exception: Illegal type Float64 of argument 3 of function s2CapUnion. Must be UInt64: In scope SELECT s2CapUnion(1157339245694594829, 3.14, nan, 3.14). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41188) (comment: 01854_s2_cap_union.sql) (query 6, line 11) (in query: select s2CapUnion(1157339245694594829, 3.14, nan, 3.14);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000008bd1817 4. DB::(anonymous namespace)::FunctionS2CapUnion::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a355b92 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:52:26.402512 [ 15875 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Float64 of argument 3 of function s2CapUnion. Must be UInt64: In scope SELECT s2CapUnion(1157339245694594829, 3.14, nan, 3.14). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000008bd1817 4. DB::(anonymous namespace)::FunctionS2CapUnion::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a355b92 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:52:26.423215 [ 15875 ] {cfb5b68f-c814-43cd-a518-ed63b8351313} executeQuery: Code: 43. DB::Exception: Radius of the cap must not be nan: In scope SELECT s2CapUnion(1157339245694594829, 3.14, 1157339245694594829, nan). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41188) (comment: 01854_s2_cap_union.sql) (query 7, line 12) (in query: select s2CapUnion(1157339245694594829, 3.14, 1157339245694594829, nan);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::(anonymous namespace)::FunctionS2CapUnion::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a353cf8 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 08:52:26.426441 [ 15875 ] {} TCPHandler: Code: 43. DB::Exception: Radius of the cap must not be nan: In scope SELECT s2CapUnion(1157339245694594829, 3.14, 1157339245694594829, nan). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::(anonymous namespace)::FunctionS2CapUnion::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a353cf8 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 08:52:28.538441 [ 9262 ] {559875e0-dc4d-4d72-98e9-3c979af31ef3} executeQuery: Code: 47. DB::Exception: Unknown expression or table expression identifier `some_identifier` in scope (_CAST(NULL, 'Nullable(Nothing)'), _CAST(NULL, 'Nullable(Nothing)'), 0) GLOBAL IN (some_identifier). (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41304) (comment: 02002_global_subqueries_subquery_or_table_name.sql) (query 1, line 3) (in query: SELECT cityHash64(number GLOBAL IN (NULL, -2147483648, -9223372036854775808), nan, 1024, NULL, NULL, 1.000100016593933, NULL), (NULL, cityHash64(inf, -2147483648, NULL, NULL, 10.000100135803223), cityHash64(1.1754943508222875e-38, NULL, NULL, NULL), 2147483647) FROM cluster(test_cluster_two_shards_localhost, numbers((NULL, cityHash64(0., 65536, NULL, NULL, 10000000000., NULL), 0) GLOBAL IN (some_identifier), 65536)) WHERE number GLOBAL IN [1025] --{ serverError BAD_ARGUMENTS, WRONG_GLOBAL_SUBQUERY, UNKNOWN_IDENTIFIER } ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000303dd3a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032b465 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:254: DB::QueryAnalyzer::resolveConstantExpression(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003033a785 9. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:115: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x00000000336b2d0b 10. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:196: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000336b81b3 11. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:102: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x00000000265c5c97 12. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:79: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000265c45e7 13. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d0326ad 14. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316edd5f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030336f50 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4785: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003032eb74 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 2025.06.13 08:52:28.543171 [ 9262 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or table expression identifier `some_identifier` in scope (_CAST(NULL, 'Nullable(Nothing)'), _CAST(NULL, 'Nullable(Nothing)'), 0) GLOBAL IN (some_identifier). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000303dd3a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032b465 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:254: DB::QueryAnalyzer::resolveConstantExpression(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003033a785 9. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:115: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x00000000336b2d0b 10. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:196: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000336b81b3 11. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:102: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x00000000265c5c97 12. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:79: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000265c45e7 13. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d0326ad 14. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316edd5f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030336f50 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4785: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003032eb74 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 2025.06.13 08:52:29.809108 [ 2133 ] {829a3338-7e38-427b-88e3-e542a010c6c1} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `t2_value` in scope SELECT toTypeName(t2_value), t2.value AS t2_value FROM test_table_join_1 AS t1 INNER JOIN test_table_join_2 USING (id). Maybe you meant: ['t2_value']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41320) (comment: 02481_analyzer_join_alias_unknown_identifier_crash.sql) (query 8, line 23) (in query: SELECT toTypeName(t2_value), t2.value AS t2_value FROM test_table_join_1 AS t1 INNER JOIN test_table_join_2 USING (id);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000303dd3a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032b465 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:52:29.813652 [ 2133 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `t2_value` in scope SELECT toTypeName(t2_value), t2.value AS t2_value FROM test_table_join_1 AS t1 INNER JOIN test_table_join_2 USING (id). Maybe you meant: ['t2_value']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000303dd3a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032b465 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:52:33.220788 [ 5285 ] {529cfa59-069a-4eba-b275-de11d512d898} executeQuery: Code: 469. DB::Exception: Constraint `c0` for table test_nj91fuge.constraint_on_nullable_type (4b65ab52-a086-4834-b961-0b6e05010afb) is violated at row 1. Expression: (id = 1). Column values: id = 0. (VIOLATED_CONSTRAINT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41452) (comment: 01720_constraints_complex_types.sql) (query 4, line 11) (in query: INSERT INTO constraint_on_nullable_type VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f626f47 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003b9da9fe 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b10197a 12. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003adbc219 13. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x000000003ad8e9f8 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:52:33.227745 [ 5285 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `c0` for table test_nj91fuge.constraint_on_nullable_type (4b65ab52-a086-4834-b961-0b6e05010afb) is violated at row 1. Expression: (id = 1). Column values: id = 0. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f626f47 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003b9da9fe 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b10197a 12. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003adbc219 13. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x000000003ad8e9f8 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:52:33.809063 [ 5285 ] {a2bbb148-1943-47f7-8ab1-7ab60f09a8a6} executeQuery: Code: 469. DB::Exception: Constraint `c0` for table test_nj91fuge.constraint_on_low_cardinality_type (2c732e5f-fc5a-45cc-9310-f1a0e9053834) is violated at row 1. Expression: (id = 2). Column values: id = 0. (VIOLATED_CONSTRAINT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41452) (comment: 01720_constraints_complex_types.sql) (query 10, line 26) (in query: INSERT INTO constraint_on_low_cardinality_type VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f626f47 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003b9da9fe 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b10197a 12. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003adbc219 13. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x000000003ad8e9f8 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:52:33.837165 [ 5285 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `c0` for table test_nj91fuge.constraint_on_low_cardinality_type (2c732e5f-fc5a-45cc-9310-f1a0e9053834) is violated at row 1. Expression: (id = 2). Column values: id = 0. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f626f47 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003b9da9fe 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b10197a 12. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003adbc219 13. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x000000003ad8e9f8 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:52:34.701094 [ 5285 ] {9505e416-c287-43a4-8723-631065f9a6ab} executeQuery: Code: 469. DB::Exception: Constraint `c0` for table test_nj91fuge.constraint_on_low_cardinality_nullable_type (3c69425f-3608-46c7-a308-711ed0e0287f) is violated at row 1. Expression: (id = 3). Column values: id = 0. (VIOLATED_CONSTRAINT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41452) (comment: 01720_constraints_complex_types.sql) (query 16, line 42) (in query: INSERT INTO constraint_on_low_cardinality_nullable_type VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f626f47 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003b9da9fe 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b10197a 12. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003adbc219 13. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x000000003ad8e9f8 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:52:34.708122 [ 5285 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `c0` for table test_nj91fuge.constraint_on_low_cardinality_nullable_type (3c69425f-3608-46c7-a308-711ed0e0287f) is violated at row 1. Expression: (id = 3). Column values: id = 0. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f626f47 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003b9da9fe 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b10197a 12. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003adbc219 13. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x000000003ad8e9f8 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:52:42.188878 [ 15862 ] {b31be3c7-3910-4258-bd1b-a270d36e48b5} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35324) (comment: 02490_benchmark_max_consecutive_errors.sh) (in query: select throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:52:42.195404 [ 15862 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:52:42.551326 [ 15867 ] {b414cccc-77aa-4941-a70e-d97b8abcbd9d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35356) (comment: 02490_benchmark_max_consecutive_errors.sh) (in query: select throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:52:42.558246 [ 15867 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:52:42.619050 [ 15837 ] {91362482-954e-4c48-abd8-cef30d8b8130} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35368) (comment: 02490_benchmark_max_consecutive_errors.sh) (in query: select throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:52:42.626763 [ 15837 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:52:42.682678 [ 15867 ] {07b6da07-1f21-43c8-9200-3352ec6c8675} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35374) (comment: 02490_benchmark_max_consecutive_errors.sh) (in query: select throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:52:42.689114 [ 15867 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:52:42.766370 [ 15862 ] {4a3566cd-575a-4a17-89c7-8c0d86222ce8} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35384) (comment: 02490_benchmark_max_consecutive_errors.sh) (in query: select throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:52:42.774969 [ 15862 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:52:42.840453 [ 9249 ] {616004df-37d1-4b07-b7dd-31d5462c4eef} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35386) (comment: 02490_benchmark_max_consecutive_errors.sh) (in query: select throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:52:42.850047 [ 9249 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:52:42.919012 [ 15862 ] {385847d7-5d57-4425-b2ea-c29025973771} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35396) (comment: 02490_benchmark_max_consecutive_errors.sh) (in query: select throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:52:42.927917 [ 15862 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:52:42.995338 [ 15875 ] {98f79376-5a96-4faf-b74b-84dced875247} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35398) (comment: 02490_benchmark_max_consecutive_errors.sh) (in query: select throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:52:43.003151 [ 15875 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:52:43.057724 [ 15862 ] {d1f2d829-c236-4eda-996e-8bab9af41c13} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37918) (comment: 02490_benchmark_max_consecutive_errors.sh) (in query: select throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:52:43.064246 [ 15862 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:52:43.120979 [ 15839 ] {d0d669af-f5b3-446b-b5bf-d0615c90fb09} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37928) (comment: 02490_benchmark_max_consecutive_errors.sh) (in query: select throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:52:43.127613 [ 15839 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:52:43.187924 [ 15862 ] {80d2ba9a-7c0b-40a9-83a5-adb82e30f27c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37942) (comment: 02490_benchmark_max_consecutive_errors.sh) (in query: select throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:52:43.195928 [ 15862 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:52:45.707883 [ 9246 ] {9a49aa65-9a49-4fda-9e55-a7adaa10a35b} executeQuery: Code: 36. DB::Exception: The 1st element of the key tuple is not of type UInt64: In scope SELECT sipHash128ReferenceKeyed((0, 0), '1'). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41418) (comment: 02552_siphash128_reference.sql) (query 129, line 203) (in query: select sipHash128ReferenceKeyed((0, 0), '1');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x00000000091702eb 5. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000094bdd6a 6. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000914c903 7. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000094bd4f2 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 2025.06.13 08:52:45.712004 [ 9246 ] {} TCPHandler: Code: 36. DB::Exception: The 1st element of the key tuple is not of type UInt64: In scope SELECT sipHash128ReferenceKeyed((0, 0), '1'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x00000000091702eb 5. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000094bdd6a 6. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000914c903 7. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000094bd4f2 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 2025.06.13 08:52:46.002326 [ 9246 ] {f8a80de4-ace2-42a5-83cf-1f71b101330b} executeQuery: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash128ReferenceKeyed(toUInt64(0), '1'). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41418) (comment: 02552_siphash128_reference.sql) (query 130, line 204) (in query: select sipHash128ReferenceKeyed(toUInt64(0), '1');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x00000000091700be 5. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000094bdd6a 6. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000914c903 7. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000094bd4f2 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 2025.06.13 08:52:46.006354 [ 9246 ] {} TCPHandler: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash128ReferenceKeyed(toUInt64(0), '1'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x00000000091700be 5. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000094bdd6a 6. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000914c903 7. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000094bd4f2 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 2025.06.13 08:52:46.268857 [ 15844 ] {} InterserverIOHTTPHandler: Code: 221. DB::Exception: No interserver IO endpoint named DataPartsExchange:default:/test/02432/test_9hzdkbr8/replicas/1. (NO_SUCH_INTERSERVER_IO_ENDPOINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./src/Interpreters/InterserverIOHandler.h:74: DB::InterserverIOHandler::getEndpoint(String const&) const @ 0x000000003ac1e048 5. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:66: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac181ce 6. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 7. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:52:46.273059 [ 1050 ] {} test_9hzdkbr8.rmt2 (d8a53e6b-5e26-4f55-a9cc-70232775e149): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://e2c95b5d5426:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02432%2Ftest_9hzdkbr8%2Freplicas%2F1&part=all_19_19_0&client_protocol_version=8&compress=false&remote_fs_metadata=s3. HTTP status code: 500 'Internal Server Error', body length: 2179 bytes, body: 'Code: 221. DB::Exception: No interserver IO endpoint named DataPartsExchange:default:/test/02432/test_9hzdkbr8/replicas/1. (NO_SUCH_INTERSERVER_IO_ENDPOINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./src/Interpreters/InterserverIOHandler.h:74: DB::InterserverIOHandler::getEndpoint(String const&) const @ 0x000000003ac1e048 5. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:66: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac181ce 6. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 7. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020149cb9 4. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020149637 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002668b3ca 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000002668b87c 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002668d238 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266944e7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 11. DB::ReadBuffer::next() @ 0x0000000008e83ccf 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 14. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 21. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 22. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:52:46.446722 [ 9215 ] {877007de-d5d3-445e-9859-45bee1afe75a} executeQuery: Code: 1. DB::Exception: Table expression modifiers FINAL are not supported for subquery SELECT 1. (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38062) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (query 2, line 3) (in query: SELECT * FROM (SELECT 1) FINAL;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:903: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030281d4d 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003025ed8a 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003026a541 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003025ea82 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000003025d3c8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae30f2 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:52:46.450554 [ 9215 ] {} TCPHandler: Code: 1. DB::Exception: Table expression modifiers FINAL are not supported for subquery SELECT 1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:903: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030281d4d 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003025ed8a 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003026a541 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003025ea82 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000003025d3c8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae30f2 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:52:46.470751 [ 9215 ] {bf58fc11-e531-4f95-b9a3-be39e9355398} executeQuery: Code: 1. DB::Exception: Table expression modifiers SAMPLE 1 / 2 are not supported for subquery SELECT 1. (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38062) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (query 3, line 4) (in query: SELECT * FROM (SELECT 1) SAMPLE 1/2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:903: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030281d4d 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003025ed8a 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003026a541 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003025ea82 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000003025d3c8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae30f2 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:52:46.474494 [ 9215 ] {} TCPHandler: Code: 1. DB::Exception: Table expression modifiers SAMPLE 1 / 2 are not supported for subquery SELECT 1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:903: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030281d4d 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003025ed8a 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003026a541 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003025ea82 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000003025d3c8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae30f2 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:52:46.500153 [ 9215 ] {11ca9cc3-2fc3-46b4-938f-5f7d3ba28c13} executeQuery: Code: 1. DB::Exception: Table expression modifiers FINAL SAMPLE 1 / 2 are not supported for subquery SELECT 1. (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38062) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (query 4, line 5) (in query: SELECT * FROM (SELECT 1) FINAL SAMPLE 1/2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:903: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030281d4d 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003025ed8a 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003026a541 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003025ea82 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000003025d3c8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae30f2 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:52:46.505613 [ 9215 ] {} TCPHandler: Code: 1. DB::Exception: Table expression modifiers FINAL SAMPLE 1 / 2 are not supported for subquery SELECT 1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:903: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030281d4d 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003025ed8a 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003026a541 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003025ea82 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000003025d3c8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae30f2 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:52:46.730816 [ 9215 ] {3b7357e5-df18-4bb7-b3cd-a06a992f387f} executeQuery: Code: 1. DB::Exception: Table expression modifiers FINAL are not supported for subquery cte_subquery AS (SELECT 1). (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38062) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (query 5, line 7) (in query: WITH cte_subquery AS (SELECT 1) SELECT * FROM cte_subquery FINAL;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4392: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c64e5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:52:46.735066 [ 9215 ] {} TCPHandler: Code: 1. DB::Exception: Table expression modifiers FINAL are not supported for subquery cte_subquery AS (SELECT 1). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4392: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c64e5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:52:46.756596 [ 9215 ] {b97cc0fc-9cec-434e-bc60-30c920f9d5f3} executeQuery: Code: 1. DB::Exception: Table expression modifiers SAMPLE 1 / 2 are not supported for subquery cte_subquery AS (SELECT 1). (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38062) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (query 6, line 8) (in query: WITH cte_subquery AS (SELECT 1) SELECT * FROM cte_subquery SAMPLE 1/2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4392: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c64e5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:52:46.760977 [ 9215 ] {} TCPHandler: Code: 1. DB::Exception: Table expression modifiers SAMPLE 1 / 2 are not supported for subquery cte_subquery AS (SELECT 1). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4392: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c64e5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:52:46.782115 [ 9215 ] {cffc45a4-b2f9-484b-9e2d-6761961db5b6} executeQuery: Code: 1. DB::Exception: Table expression modifiers FINAL SAMPLE 1 / 2 are not supported for subquery cte_subquery AS (SELECT 1). (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38062) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (query 7, line 9) (in query: WITH cte_subquery AS (SELECT 1) SELECT * FROM cte_subquery FINAL SAMPLE 1/2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4392: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c64e5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:52:46.786090 [ 9215 ] {} TCPHandler: Code: 1. DB::Exception: Table expression modifiers FINAL SAMPLE 1 / 2 are not supported for subquery cte_subquery AS (SELECT 1). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4392: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c64e5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:52:46.808501 [ 9215 ] {b8a6a43f-66ea-4d44-af17-d4c20beeb285} executeQuery: Code: 1. DB::Exception: Table expression modifiers FINAL are not supported for subquery SELECT 1 UNION ALL SELECT 1. (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38062) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (query 8, line 11) (in query: SELECT * FROM (SELECT 1 UNION ALL SELECT 1) FINAL;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:903: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030281d4d 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003025ed8a 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003026a541 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003025ea82 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000003025d3c8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae30f2 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:52:46.812351 [ 9215 ] {} TCPHandler: Code: 1. DB::Exception: Table expression modifiers FINAL are not supported for subquery SELECT 1 UNION ALL SELECT 1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:903: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030281d4d 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003025ed8a 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003026a541 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003025ea82 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000003025d3c8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae30f2 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:52:46.831641 [ 9215 ] {0c4c751b-b2fb-4978-ae51-83ba23405571} executeQuery: Code: 1. DB::Exception: Table expression modifiers SAMPLE 1 / 2 are not supported for subquery SELECT 1 UNION ALL SELECT 1. (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38062) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (query 9, line 12) (in query: SELECT * FROM (SELECT 1 UNION ALL SELECT 1) SAMPLE 1/2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:903: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030281d4d 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003025ed8a 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003026a541 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003025ea82 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000003025d3c8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae30f2 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:52:46.835128 [ 9215 ] {} TCPHandler: Code: 1. DB::Exception: Table expression modifiers SAMPLE 1 / 2 are not supported for subquery SELECT 1 UNION ALL SELECT 1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:903: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030281d4d 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003025ed8a 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003026a541 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003025ea82 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000003025d3c8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae30f2 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:52:46.853915 [ 9215 ] {4a723a1e-d6b8-47d1-8e86-cb70fdd92a3e} executeQuery: Code: 1. DB::Exception: Table expression modifiers FINAL SAMPLE 1 / 2 are not supported for subquery SELECT 1 UNION ALL SELECT 1. (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38062) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (query 10, line 13) (in query: SELECT * FROM (SELECT 1 UNION ALL SELECT 1) FINAL SAMPLE 1/2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:903: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030281d4d 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003025ed8a 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003026a541 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003025ea82 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000003025d3c8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae30f2 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:52:46.857960 [ 9215 ] {} TCPHandler: Code: 1. DB::Exception: Table expression modifiers FINAL SAMPLE 1 / 2 are not supported for subquery SELECT 1 UNION ALL SELECT 1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:903: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030281d4d 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003025ed8a 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003026a541 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003025ea82 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000003025d3c8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae30f2 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:52:46.881015 [ 9215 ] {33d62cd4-fba1-4d78-bb23-6ad56ebad72e} executeQuery: Code: 1. DB::Exception: Table expression modifiers FINAL are not supported for subquery cte_subquery AS (SELECT 1 UNION ALL SELECT 1). (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38062) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (query 11, line 15) (in query: WITH cte_subquery AS (SELECT 1 UNION ALL SELECT 1) SELECT * FROM cte_subquery FINAL;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4392: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c64e5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:52:46.884568 [ 9215 ] {} TCPHandler: Code: 1. DB::Exception: Table expression modifiers FINAL are not supported for subquery cte_subquery AS (SELECT 1 UNION ALL SELECT 1). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4392: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c64e5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:52:46.904904 [ 9215 ] {9ab1214d-f9bf-4fed-bbf8-0f47747d05b1} executeQuery: Code: 1. DB::Exception: Table expression modifiers SAMPLE 1 / 2 are not supported for subquery cte_subquery AS (SELECT 1 UNION ALL SELECT 1). (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38062) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (query 12, line 16) (in query: WITH cte_subquery AS (SELECT 1 UNION ALL SELECT 1) SELECT * FROM cte_subquery SAMPLE 1/2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4392: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c64e5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:52:46.908723 [ 9215 ] {} TCPHandler: Code: 1. DB::Exception: Table expression modifiers SAMPLE 1 / 2 are not supported for subquery cte_subquery AS (SELECT 1 UNION ALL SELECT 1). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4392: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c64e5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:52:46.930994 [ 9215 ] {40052117-b0a8-4f0b-bc27-e2138f017313} executeQuery: Code: 1. DB::Exception: Table expression modifiers FINAL SAMPLE 1 / 2 are not supported for subquery cte_subquery AS (SELECT 1 UNION ALL SELECT 1). (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38062) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (query 13, line 17) (in query: WITH cte_subquery AS (SELECT 1 UNION ALL SELECT 1) SELECT * FROM cte_subquery FINAL SAMPLE 1/2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4392: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c64e5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:52:46.935626 [ 9215 ] {} TCPHandler: Code: 1. DB::Exception: Table expression modifiers FINAL SAMPLE 1 / 2 are not supported for subquery cte_subquery AS (SELECT 1 UNION ALL SELECT 1). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4392: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c64e5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:52:55.318328 [ 3514 ] {52f387f8-8b6d-4fd6-8545-73c4cbbc64c7} executeQuery: Code: 36. DB::Exception: Needle must not contain whitespace or separator characters: while executing 'FUNCTION hasToken(s : 0, 'abc,def,zzz'_String :: 1) -> hasToken(__table1.s, 'abc,def,zzz'_String) UInt8 : 2': While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35656) (comment: 00990_hasToken_and_tokenbf.sql) (query 7, line 15) (in query: SELECT max(id) FROM bloom_filter WHERE hasToken(s, 'abc,def,zzz');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::HasTokenImpl>, false>::vectorConstant(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, String const&, COW::immutable_ptr const&, DB::PODArray, 63ul, 64ul>&, DB::ColumnVector*, unsigned long) @ 0x000000001158bf3c 5. DB::FunctionsStringSearch>, false>, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011585d0e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000031a8d8ca 12. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1394: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) const @ 0x0000000039dcc9aa 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:110: DB::MergeTreeReadersChain::executePrewhereActions(DB::MergeTreeRangeReader&, DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) @ 0x0000000039e28352 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:75: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039e26a8a 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039e15d8b 16. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c253bd1 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000039e3e49b 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c200ea7 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:52:55.328531 [ 3514 ] {} TCPHandler: Code: 36. DB::Exception: Needle must not contain whitespace or separator characters: while executing 'FUNCTION hasToken(s : 0, 'abc,def,zzz'_String :: 1) -> hasToken(__table1.s, 'abc,def,zzz'_String) UInt8 : 2': While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::HasTokenImpl>, false>::vectorConstant(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, String const&, COW::immutable_ptr const&, DB::PODArray, 63ul, 64ul>&, DB::ColumnVector*, unsigned long) @ 0x000000001158bf3c 5. DB::FunctionsStringSearch>, false>, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011585d0e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000031a8d8ca 12. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1394: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) const @ 0x0000000039dcc9aa 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:110: DB::MergeTreeReadersChain::executePrewhereActions(DB::MergeTreeRangeReader&, DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) @ 0x0000000039e28352 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:75: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039e26a8a 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039e15d8b 16. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c253bd1 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000039e3e49b 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c200ea7 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:52:55.635239 [ 3514 ] {6978c73d-567f-49fc-8be4-8c0ea4485345} executeQuery: Code: 36. DB::Exception: Needle must not contain whitespace or separator characters: while executing 'FUNCTION hasTokenCaseInsensitive(s : 0, 'abc,def,zzz'_String :: 1) -> hasTokenCaseInsensitive(__table1.s, 'abc,def,zzz'_String) UInt8 : 2': While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35656) (comment: 00990_hasToken_and_tokenbf.sql) (query 8, line 16) (in query: SELECT max(id) FROM bloom_filter WHERE hasTokenCaseInsensitive(s, 'abc,def,zzz');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::HasTokenImpl>, false>::vectorConstant(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, String const&, COW::immutable_ptr const&, DB::PODArray, 63ul, 64ul>&, DB::ColumnVector*, unsigned long) @ 0x000000001159d89c 5. DB::FunctionsStringSearch>, false>, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001159764e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000031a8d8ca 12. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1394: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) const @ 0x0000000039dcc9aa 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:110: DB::MergeTreeReadersChain::executePrewhereActions(DB::MergeTreeRangeReader&, DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) @ 0x0000000039e28352 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:75: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039e26a8a 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039e15d8b 16. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c253bd1 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000039e3e49b 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c200ea7 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:52:55.642242 [ 3514 ] {} TCPHandler: Code: 36. DB::Exception: Needle must not contain whitespace or separator characters: while executing 'FUNCTION hasTokenCaseInsensitive(s : 0, 'abc,def,zzz'_String :: 1) -> hasTokenCaseInsensitive(__table1.s, 'abc,def,zzz'_String) UInt8 : 2': While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::HasTokenImpl>, false>::vectorConstant(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, String const&, COW::immutable_ptr const&, DB::PODArray, 63ul, 64ul>&, DB::ColumnVector*, unsigned long) @ 0x000000001159d89c 5. DB::FunctionsStringSearch>, false>, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001159764e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000031a8d8ca 12. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1394: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) const @ 0x0000000039dcc9aa 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:110: DB::MergeTreeReadersChain::executePrewhereActions(DB::MergeTreeRangeReader&, DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) @ 0x0000000039e28352 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:75: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039e26a8a 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039e15d8b 16. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c253bd1 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000039e3e49b 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c200ea7 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:52:56.863300 [ 2141 ] {dc5736c5-b06e-4214-af1a-7b645f278a85} executeQuery: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION intDiv(__table1.b :: 2, __table1.c :: 0) -> intDiv(__table1.b, __table1.c) Int32 : 1'. (ILLEGAL_DIVISION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35746) (comment: 02481_prewhere_filtered_rows_div_by_zero.sql) (query 5, line 10) (in query: -- Check that division by zero occurs on some rows SELECT intDiv(b, c) FROM test_filter;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. void DB::throwIfDivisionLeadsToFPE(int, int) @ 0x000000000d308111 5. void DB::(anonymous namespace)::DivideIntegralByConstantImpl::process<(DB::impl_::OpCase)0>(int const*, int const*, int*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000011648d04 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000011e78acc 7. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeNumber>(auto const&, auto const&) const @ 0x0000000011e77b90 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000011e66509 9. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000011ceffdd 10. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000011ce5ef2 11. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011ce04ad 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 17. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:52:56.870244 [ 2141 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION intDiv(__table1.b :: 2, __table1.c :: 0) -> intDiv(__table1.b, __table1.c) Int32 : 1'. (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. void DB::throwIfDivisionLeadsToFPE(int, int) @ 0x000000000d308111 5. void DB::(anonymous namespace)::DivideIntegralByConstantImpl::process<(DB::impl_::OpCase)0>(int const*, int const*, int*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000011648d04 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000011e78acc 7. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeNumber>(auto const&, auto const&) const @ 0x0000000011e77b90 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000011e66509 9. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000011ceffdd 10. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000011ce5ef2 11. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011ce04ad 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 17. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:52:57.354500 [ 1384 ] {f3740cef-e646-4a70-baf4-fad04b030ce8} test_o41qbjit.rmt (ReplicatedMergeTreePartCheckThread): ReplicatedCheckResult DB::ReplicatedMergeTreePartCheckThread::checkPartImpl(const String &, bool): Code: 107. DB::ErrnoException: Cannot open file /var/lib/clickhouse/store/975/975ae197-a58f-4b88-9e7d-d8aa15849a6d/0_0_0_0/columns.txt: , errno: 2, strerror: No such file or directory. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x000000001f83902f 4. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x000000001f838788 5. ./build_docker/./src/IO/OpenedFile.cpp:33: DB::OpenedFile::getFD() const @ 0x000000002d06812d 6. ./src/IO/ReadBufferFromFile.h:101: DB::ReadBufferFromFilePReadWithDescriptorsCache::ReadBufferFromFilePReadWithDescriptorsCache(String const&, unsigned long, int, char*, unsigned long, std::optional, std::shared_ptr) @ 0x000000002d0544c5 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long)::$_0::operator()(unsigned long, unsigned long, int) const @ 0x000000002d052f23 8. ./build_docker/./src/Disks/IO/createReadBufferFromFileBase.cpp:213: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long) @ 0x000000002d052b2b 9. ./build_docker/./src/Disks/DiskLocal.cpp:343: DB::DiskLocal::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x000000002fd454d5 10. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:131: DB::DataPartStorageOnDiskFull::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x000000003943713e 11. ./build_docker/./src/Storages/MergeTree/checkDataPart.cpp:170: DB::checkDataPart(std::shared_ptr, DB::IDataPartStorage const&, DB::NamesAndTypesList const&, DB::MergeTreeDataPartType const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::ReadSettings const&, bool, std::function, bool&, bool) @ 0x000000003a35630a 12. ./build_docker/./src/Storages/MergeTree/checkDataPart.cpp:478: DB::checkDataPart(std::shared_ptr, bool, bool&, std::function, bool) @ 0x000000003a354ac1 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreePartCheckThread.cpp:372: DB::ReplicatedMergeTreePartCheckThread::checkPartImpl(String const&, bool) @ 0x000000003a1974ce 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreePartCheckThread.cpp:451: DB::ReplicatedMergeTreePartCheckThread::checkPartAndFix(String const&, std::optional*, bool) @ 0x000000003a1a03c1 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:9529: DB::StorageReplicatedMergeTree::checkDataNext(std::shared_ptr&) @ 0x0000000038b08feb 16. ./build_docker/./src/Interpreters/InterpreterCheckQuery.cpp:142: DB::(anonymous namespace)::TableCheckWorkerProcessor::transform(DB::Chunk&) @ 0x000000003389a0e8 17. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:52:57.355764 [ 1384 ] {f3740cef-e646-4a70-baf4-fad04b030ce8} test_o41qbjit.rmt (ReplicatedMergeTreePartCheckThread): Part 0_0_0_0 looks broken. Removing it and will try to fetch. 2025.06.13 08:52:57.356470 [ 1384 ] {f3740cef-e646-4a70-baf4-fad04b030ce8} test_o41qbjit.rmt (ReplicatedMergeTreePartCheckThread): Part 0_0_0_0 exists in ZooKeeper and the local part was broken. Detaching it, removing from ZooKeeper and queueing a fetch. 2025.06.13 08:52:57.358758 [ 1384 ] {f3740cef-e646-4a70-baf4-fad04b030ce8} test_o41qbjit.rmt (975ae197-a58f-4b88-9e7d-d8aa15849a6d): Detached 1 parts covered by broken part 0_0_0_0: 0_0_0_0 2025.06.13 08:52:57.377306 [ 1384 ] {f3740cef-e646-4a70-baf4-fad04b030ce8} InterpreterCheckQuery: Check query for table test_o41qbjit.rmt (975ae197-a58f-4b88-9e7d-d8aa15849a6d) failed, path 0_0_0_0, reason: Part 0_0_0_0 looks broken. Removing it and will try to fetch. 2025.06.13 08:52:57.397559 [ 647 ] {} test_o41qbjit.rmt (975ae197-a58f-4b88-9e7d-d8aa15849a6d): Directory /var/lib/clickhouse/store/975/975ae197-a58f-4b88-9e7d-d8aa15849a6d/0_0_0_0 (part to remove) doesn't exist or one of nested files has gone. Most likely this is due to manual removing. This should be discouraged. Ignoring. 2025.06.13 08:52:57.655282 [ 824 ] {} test_o41qbjit.rmt (ReplicatedMergeTreePartCheckThread): No replica has part covering 0_0_0_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.06.13 08:52:57.786469 [ 824 ] {} test_o41qbjit.rmt (ReplicatedMergeTreePartCheckThread): Part 0_0_0_0 is lost forever. 2025.06.13 08:52:58.231250 [ 3514 ] {98811b47-9a18-4265-964a-aab308c84201} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 16.00, current rows: 2.05 thousand. (TOO_MANY_ROWS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35656) (comment: 00990_hasToken_and_tokenbf.sql) (query 30, line 51) (in query: -- invert result -- this does not work as expected, reading more rows that it should -- SELECT max(id) FROM bloom_filter WHERE NOT hasToken(s, 'yyy'); -- accessing to many rows SELECT max(id) FROM bloom_filter WHERE hasToken(s, 'yyy');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f24bc97 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f24776e 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f247bac 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000003c166bc3 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1c31d7 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049298 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:52:58.236894 [ 3514 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 16.00, current rows: 2.05 thousand. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f24bc97 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f24776e 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f247bac 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000003c166bc3 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1c31d7 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049298 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:52:58.323932 [ 3514 ] {e28e609a-516e-4e19-bdb5-a8ecbd8bd151} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 16.00, current rows: 3.08 thousand. (TOO_MANY_ROWS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35656) (comment: 00990_hasToken_and_tokenbf.sql) (query 31, line 58) (in query: -- this syntax is not supported by tokenbf SELECT max(id) FROM bloom_filter WHERE hasToken(s, 'zzz') == 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f24bc97 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f24776e 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f247bac 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000003c166bc3 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1c31d7 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049298 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:52:58.328384 [ 3514 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 16.00, current rows: 3.08 thousand. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f24bc97 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f24776e 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f247bac 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000003c166bc3 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1c31d7 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049298 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:52:58.922978 [ 15861 ] {34b9ab3b-8cf7-4fd2-abb6-58fb936cdbd3} executeQuery: Code: 43. DB::Exception: Nested type Array(String) cannot be inside Nullable type. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35864) (comment: 01159_combinators_with_parameters.sql) (query 6, line 6) (in query: SELECT toTypeName(topKOrNullState(10)(toString(number))) FROM numbers(100);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/DataTypes/DataTypeNullable.cpp:31: DB::DataTypeNullable::DataTypeNullable(std::shared_ptr const&) @ 0x000000002f2cfbe3 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr const&, 0>(std::allocator const&, std::shared_ptr const&) @ 0x0000000026567586 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::AggregateFunctionOrFill::AggregateFunctionOrFill(std::shared_ptr, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000026561cf5 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr> std::allocate_shared[abi:ne190107], std::allocator>, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator> const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000026561664 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::AggregateFunctionCombinatorOrFill::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x000000002656130c 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002d00a044 10. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 11. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002d009778 12. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303855f9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:52:58.928520 [ 15861 ] {} TCPHandler: Code: 43. DB::Exception: Nested type Array(String) cannot be inside Nullable type. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/DataTypes/DataTypeNullable.cpp:31: DB::DataTypeNullable::DataTypeNullable(std::shared_ptr const&) @ 0x000000002f2cfbe3 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr const&, 0>(std::allocator const&, std::shared_ptr const&) @ 0x0000000026567586 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::AggregateFunctionOrFill::AggregateFunctionOrFill(std::shared_ptr, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000026561cf5 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr> std::allocate_shared[abi:ne190107], std::allocator>, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator> const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000026561664 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::AggregateFunctionCombinatorOrFill::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x000000002656130c 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002d00a044 10. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 11. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002d009778 12. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303855f9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:53:01.659129 [ 24861 ] {4294533d-da5b-49d4-b049-7ac97c1a33c6} executeQuery: Code: 41. DB::Exception: Cannot parse DateTime: Cannot parse DateTime64(3, 'UTC') from String: In scope SELECT toDateTime64('1234', 3, 'UTC'). (CANNOT_PARSE_DATETIME) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36062) (comment: 02889_datetime64_from_string.sql) (query 6, line 8) (in query: SELECT toDateTime64('1234', 3, 'UTC');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/IO/ReadHelpers.cpp:1597: void DB::readDateTimeTextFallback(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x000000001f8cfbcc 5. void DB::readDateTimeTextImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x000000001a9af3ee 6. void DB::readDateTimeTextImpl(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x000000001a9ae621 7. ./src/IO/ReadHelpers.h:1221: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002cc104ee 8. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cbedfe9 9. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c7f0e23 10. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c83f477 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c83e462 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 2025.06.13 08:53:01.663242 [ 24861 ] {} TCPHandler: Code: 41. DB::Exception: Cannot parse DateTime: Cannot parse DateTime64(3, 'UTC') from String: In scope SELECT toDateTime64('1234', 3, 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/IO/ReadHelpers.cpp:1597: void DB::readDateTimeTextFallback(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x000000001f8cfbcc 5. void DB::readDateTimeTextImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x000000001a9af3ee 6. void DB::readDateTimeTextImpl(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x000000001a9ae621 7. ./src/IO/ReadHelpers.h:1221: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002cc104ee 8. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cbedfe9 9. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c7f0e23 10. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c83f477 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c83e462 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 2025.06.13 08:53:01.683535 [ 24861 ] {c867ad6c-6853-42e2-8e82-e5917471f6ab} executeQuery: Code: 41. DB::Exception: Cannot parse DateTime: Cannot parse DateTime64(3, 'UTC') from String: In scope SELECT toDateTime64('0', 3, 'UTC'). (CANNOT_PARSE_DATETIME) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36062) (comment: 02889_datetime64_from_string.sql) (query 7, line 9) (in query: SELECT toDateTime64('0', 3, 'UTC');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/IO/ReadHelpers.cpp:1597: void DB::readDateTimeTextFallback(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x000000001f8cfbcc 5. void DB::readDateTimeTextImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x000000001a9af3ee 6. void DB::readDateTimeTextImpl(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x000000001a9ae621 7. ./src/IO/ReadHelpers.h:1221: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002cc104ee 8. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cbedfe9 9. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c7f0e23 10. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c83f477 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c83e462 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 2025.06.13 08:53:01.687767 [ 24861 ] {} TCPHandler: Code: 41. DB::Exception: Cannot parse DateTime: Cannot parse DateTime64(3, 'UTC') from String: In scope SELECT toDateTime64('0', 3, 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/IO/ReadHelpers.cpp:1597: void DB::readDateTimeTextFallback(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x000000001f8cfbcc 5. void DB::readDateTimeTextImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x000000001a9af3ee 6. void DB::readDateTimeTextImpl(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x000000001a9ae621 7. ./src/IO/ReadHelpers.h:1221: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002cc104ee 8. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cbedfe9 9. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c7f0e23 10. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c83f477 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c83e462 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 2025.06.13 08:53:01.977469 [ 24861 ] {063b3f5b-ece1-4a97-bb5e-169f2adf7f46} executeQuery: Code: 41. DB::Exception: Cannot parse DateTime: In scope SELECT CAST('0', 'DateTime64(3, \'UTC\')'). (CANNOT_PARSE_DATETIME) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36062) (comment: 02889_datetime64_from_string.sql) (query 8, line 10) (in query: SELECT cast('0' as DateTime64(3, 'UTC'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/IO/ReadHelpers.cpp:1597: void DB::readDateTimeTextFallback(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x000000001f8cfbcc 5. void DB::readDateTimeTextImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x000000001a9af3ee 6. void DB::readDateTimeTextImpl(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x000000001a9ae621 7. COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002c7347ce 8. bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(T const&)::operator()>(T const&) const @ 0x000000002c720312 9. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c71a700 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c719564 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008bec782 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 2025.06.13 08:53:01.981987 [ 24861 ] {} TCPHandler: Code: 41. DB::Exception: Cannot parse DateTime: In scope SELECT CAST('0', 'DateTime64(3, \'UTC\')'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/IO/ReadHelpers.cpp:1597: void DB::readDateTimeTextFallback(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x000000001f8cfbcc 5. void DB::readDateTimeTextImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x000000001a9af3ee 6. void DB::readDateTimeTextImpl(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x000000001a9ae621 7. COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002c7347ce 8. bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(T const&)::operator()>(T const&) const @ 0x000000002c720312 9. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c71a700 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c719564 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008bec782 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 2025.06.13 08:53:03.112093 [ 2085 ] {bdedb814-c1cd-4b36-bc42-9551b0557930} executeQuery: Code: 128. DB::Exception: Too large array element size 18446744073709551615 (maximum: 16777215): While executing CSVRowInputFormat. (TOO_LARGE_ARRAY_SIZE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36114) (comment: 02681_group_array_too_large_size.sql) (query 1, line 1) (in query: -- This query throw high-level exception instead of low-level "too large size passed to allocator": SELECT * FROM format(CSV, 'entitypArray AggregateFunction(groupArray, String)', '295TMiews.viewNÿÿÿÿÿ""""""TabSeparÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿated d St"" r');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b1188ad 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:404: DB::(anonymous namespace)::GroupArrayNodeBase::read(DB::ReadBuffer&, DB::Arena*) @ 0x0000000020b664a3 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:689: DB::(anonymous namespace)::GroupArrayGeneralImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000020c09ceb 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f4f6b11 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:192: DB::SerializationAggregateFunction::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f4f7cd2 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:0: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000002f623433 9. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f61f402 10. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:394: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003b3d374b 11. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b31c579 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b274d5f 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b108bd9 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b0f6008 21. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000266c3409 22. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d0326ad 23. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316edd5f 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030336f50 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 2025.06.13 08:53:03.118839 [ 2085 ] {} TCPHandler: Code: 128. DB::Exception: Too large array element size 18446744073709551615 (maximum: 16777215): While executing CSVRowInputFormat. (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b1188ad 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:404: DB::(anonymous namespace)::GroupArrayNodeBase::read(DB::ReadBuffer&, DB::Arena*) @ 0x0000000020b664a3 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:689: DB::(anonymous namespace)::GroupArrayGeneralImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000020c09ceb 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f4f6b11 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:192: DB::SerializationAggregateFunction::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f4f7cd2 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:0: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000002f623433 9. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f61f402 10. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:394: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003b3d374b 11. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b31c579 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b274d5f 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b108bd9 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b0f6008 21. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000266c3409 22. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d0326ad 23. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316edd5f 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030336f50 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 2025.06.13 08:53:07.743076 [ 404 ] {d2be437d-b406-4e8b-bb16-be5b83fcd2e5} executeQuery: Code: 117. DB::Exception: Incorrect data: Sign = 2 (must be 1 or -1). (INCORRECT_DATA) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33938) (comment: 03291_collapsing_invalid_sign.sql) (query 4, line 13) (in query: INSERT INTO t_03291_collapsing_invalid_sign VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Processors/Merges/Algorithms/CollapsingSortedAlgorithm.cpp:222: DB::CollapsingSortedAlgorithm::merge() @ 0x000000003bd71bd9 5. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:464: DB::MergeTreeDataWriter::mergeBlock(DB::Block&&, DB::SortDescription, std::vector> const&, DB::PODArray, 63ul, 64ul>*&, DB::MergeTreeData::MergingParams const&) @ 0x0000000039b7d044 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:613: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039b83663 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039b7e7f7 8. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a46b83d 9. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b10197a 17. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003adbc219 18. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x000000003ad8e9f8 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:53:07.749984 [ 404 ] {} TCPHandler: Code: 117. DB::Exception: Incorrect data: Sign = 2 (must be 1 or -1). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Processors/Merges/Algorithms/CollapsingSortedAlgorithm.cpp:222: DB::CollapsingSortedAlgorithm::merge() @ 0x000000003bd71bd9 5. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:464: DB::MergeTreeDataWriter::mergeBlock(DB::Block&&, DB::SortDescription, std::vector> const&, DB::PODArray, 63ul, 64ul>*&, DB::MergeTreeData::MergingParams const&) @ 0x0000000039b7d044 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:613: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039b83663 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039b7e7f7 8. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a46b83d 9. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b10197a 17. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003adbc219 18. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x000000003ad8e9f8 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:53:07.917020 [ 4763 ] {034874b2-ef40-404b-b554-5a3ea9afb7ea} CollapsingSortedTransform: Incorrect data: Sign = 2 (must be 1 or -1). 2025.06.13 08:53:08.615538 [ 9237 ] {6065228d-a456-45f2-be09-272381990cf5} executeQuery: Code: 407. DB::Exception: Intermediate result overflow (signed a = -256, signed b = 9223372036854775807, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT ignore(lcm(-256, 9223372036854775807)). (DECIMAL_OVERFLOW) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33952) (comment: 01435_lcm_overflow.sql) (query 7, line 9) (in query: SELECT ignore(lcm(-256, 9223372036854775807));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000000f013cff 4. long DB::GCDLCMImpl, DB::(anonymous namespace)::NameLCM>::apply(short, unsigned long) @ 0x00000000128f6bda 5. _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_17LCMImplENS12_7NameLCMELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clISE_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x0000000012a27581 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001294f486 7. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000012945165 8. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012941015 9. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001293d82d 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 2025.06.13 08:53:08.619867 [ 9237 ] {} TCPHandler: Code: 407. DB::Exception: Intermediate result overflow (signed a = -256, signed b = 9223372036854775807, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT ignore(lcm(-256, 9223372036854775807)). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000000f013cff 4. long DB::GCDLCMImpl, DB::(anonymous namespace)::NameLCM>::apply(short, unsigned long) @ 0x00000000128f6bda 5. _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_17LCMImplENS12_7NameLCMELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clISE_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x0000000012a27581 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001294f486 7. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000012945165 8. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012941015 9. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001293d82d 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 2025.06.13 08:53:08.763790 [ 9260 ] {6207bbd0-7a7e-40a6-90a1-a9a29f81c3fe} executeQuery: Code: 519. DB::NetException: All attempts to get table structure failed. Log: Code: 279. DB::NetException: All connection tries failed. Log: Timeout exceeded while connecting to socket (128.1.2.3:9000, connection timeout 1 ms) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.3.20286.altinityantalya (altinity build)) . (ALL_CONNECTION_TRIES_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) . (NO_REMOTE_SHARD_AVAILABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33980) (comment: 01361_fover_remote_num_tries.sh) (query 1, line 1) (in query: SELECT hostName() FROM remote('128.1.2.3', default.tmp)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038e302d6 3. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:177: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000038e2b1f8 4. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:337: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002659d189 5. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:309: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002659b639 6. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d0326ad 7. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316edd5f 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030336f50 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:53:08.773920 [ 9260 ] {} TCPHandler: Code: 519. DB::NetException: All attempts to get table structure failed. Log: Code: 279. DB::NetException: All connection tries failed. Log: Timeout exceeded while connecting to socket (128.1.2.3:9000, connection timeout 1 ms) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.3.20286.altinityantalya (altinity build)) . (ALL_CONNECTION_TRIES_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) . (NO_REMOTE_SHARD_AVAILABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038e302d6 3. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:177: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000038e2b1f8 4. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:337: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002659d189 5. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:309: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002659b639 6. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d0326ad 7. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316edd5f 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030336f50 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:53:08.862919 [ 1018 ] {20e6dd0a-7c20-49a7-9ab2-4d0acbcc33a3::all_1_6_1} CollapsingSortedTransform: Incorrect data: Sign = 0 (must be 1 or -1). 2025.06.13 08:53:08.864736 [ 1018 ] {20e6dd0a-7c20-49a7-9ab2-4d0acbcc33a3::all_1_6_1} CollapsingSortedTransform: Incorrect data: number of rows with sign = 1 (71) differs with number of rows with sign = -1 (67) by more than one (for key: ).). 2025.06.13 08:53:08.890730 [ 1384 ] {7ca1e8ca-5fec-48de-8302-3b2fdd113d79} CollapsingSortedTransform: Incorrect data: Sign = 0 (must be 1 or -1). 2025.06.13 08:53:08.892124 [ 1384 ] {7ca1e8ca-5fec-48de-8302-3b2fdd113d79} CollapsingSortedTransform: Incorrect data: number of rows with sign = 1 (71) differs with number of rows with sign = -1 (67) by more than one (for key: ).). 2025.06.13 08:53:09.553496 [ 404 ] {2b22bce5-582e-4c14-bfd1-076a3214005e::all_1_2_1} CollapsingSortedTransform: Incorrect data: Sign = 0 (must be 1 or -1). 2025.06.13 08:53:09.554160 [ 404 ] {2b22bce5-582e-4c14-bfd1-076a3214005e::all_1_2_1} CollapsingSortedTransform: Incorrect data: Sign = 0 (must be 1 or -1). 2025.06.13 08:53:09.919460 [ 10592 ] {16ed589b-a516-473e-9ce6-f051a696a365} CollapsingSortedTransform: Incorrect data: Sign = 0 (must be 1 or -1). 2025.06.13 08:53:10.887659 [ 15860 ] {c74836b5-2c21-49ae-adb2-19945c4fb8c9} executeQuery: Code: 497. DB::Exception: user03247_test_6kjp606f_28510: Not enough privileges. To execute this query, it's necessary to have the grant SHOW TABLES ON test_03247.`table`. (ACCESS_DENIED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34050) (comment: 03247_show_grants_with_implicit.sh) (query 1, line 1) (in query: EXISTS test_03247.table;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002e2f365b 4. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x000000002e2efb16 5. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002e2ee086 6. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002e2667f8 7. ./src/Access/ContextAccess.h:256: void DB::Context::checkAccessImpl>, std::basic_string_view>>(DB::AccessFlags const&, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000003177042f 8. ./build_docker/./src/Interpreters/Context.cpp:1755: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x00000000316d430f 9. ./build_docker/./src/Interpreters/InterpreterExistsQuery.cpp:54: DB::InterpreterExistsQuery::executeImpl() @ 0x000000003385f727 10. ./build_docker/./src/Interpreters/InterpreterExistsQuery.cpp:25: DB::InterpreterExistsQuery::execute() @ 0x000000003385e3a4 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:53:10.899760 [ 15860 ] {} TCPHandler: Code: 497. DB::Exception: user03247_test_6kjp606f_28510: Not enough privileges. To execute this query, it's necessary to have the grant SHOW TABLES ON test_03247.`table`. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002e2f365b 4. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x000000002e2efb16 5. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002e2ee086 6. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002e2667f8 7. ./src/Access/ContextAccess.h:256: void DB::Context::checkAccessImpl>, std::basic_string_view>>(DB::AccessFlags const&, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000003177042f 8. ./build_docker/./src/Interpreters/Context.cpp:1755: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x00000000316d430f 9. ./build_docker/./src/Interpreters/InterpreterExistsQuery.cpp:54: DB::InterpreterExistsQuery::executeImpl() @ 0x000000003385f727 10. ./build_docker/./src/Interpreters/InterpreterExistsQuery.cpp:25: DB::InterpreterExistsQuery::execute() @ 0x000000003385e3a4 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:53:11.135050 [ 9224 ] {34d31ebd-9445-4ac9-869c-f268ce9be526} executeQuery: Code: 36. DB::Exception: Default codec cannot have any arguments, it's just an alias for codec specified in config.xml. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34038) (comment: 01455_default_compression.sql) (query 10, line 27) (in query: ALTER TABLE compress_table MODIFY COLUMN value2 CODEC(Default(5));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c2574a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:118: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003dd494da 5. ./build_docker/./src/Storages/AlterCommands.cpp:1493: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000038192b80 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 08:53:11.138943 [ 9224 ] {} TCPHandler: Code: 36. DB::Exception: Default codec cannot have any arguments, it's just an alias for codec specified in config.xml. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c2574a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:118: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003dd494da 5. ./build_docker/./src/Storages/AlterCommands.cpp:1493: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000038192b80 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 08:53:11.737483 [ 9224 ] {5977d84d-c54d-44be-bb22-7f3a00b15b55} executeQuery: Code: 336. DB::Exception: Ordinary database engine is deprecated (see also allow_deprecated_database_ordinary setting). (UNKNOWN_DATABASE_ENGINE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34094) (comment: 01114_database_atomic.sh) (query 1, line 1) (in query: CREATE DATABASE test_ma5xkj47_1 ENGINE=Ordinary), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Databases/DatabaseOrdinary.cpp:647: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x000000002f8c3884 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f831acb 6. ./build_docker/./src/Databases/DatabaseFactory.cpp:111: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x000000002f8303c7 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:341: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000328bbd02 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3a0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:53:11.742093 [ 9224 ] {} TCPHandler: Code: 336. DB::Exception: Ordinary database engine is deprecated (see also allow_deprecated_database_ordinary setting). (UNKNOWN_DATABASE_ENGINE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Databases/DatabaseOrdinary.cpp:647: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x000000002f8c3884 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f831acb 6. ./build_docker/./src/Databases/DatabaseFactory.cpp:111: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x000000002f8303c7 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:341: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000328bbd02 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3a0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:53:12.793310 [ 15871 ] {4878c933-798b-499f-90eb-e3811f718748} executeQuery: Code: 36. DB::Exception: Using storage_file_read_method=mmap is not safe in server mode. Consider using pread.: While executing File. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34178) (comment: 02497_storage_file_reader_selection.sh) (query 1, line 1) (in query: SELECT * FROM file('/dev/null', 'LineAsString') FORMAT Null -- { serverError BAD_ARGUMENTS }), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageFile.cpp:285: DB::(anonymous namespace)::createReadBuffer(String const&, stat const&, bool, int, String const&, std::shared_ptr) @ 0x00000000383f90ab 5. ./build_docker/./src/Storages/StorageFile.cpp:1429: DB::StorageFileSource::generate() @ 0x0000000038416da3 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 08:53:12.801848 [ 15871 ] {} TCPHandler: Code: 36. DB::Exception: Using storage_file_read_method=mmap is not safe in server mode. Consider using pread.: While executing File. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageFile.cpp:285: DB::(anonymous namespace)::createReadBuffer(String const&, stat const&, bool, int, String const&, std::shared_ptr) @ 0x00000000383f90ab 5. ./build_docker/./src/Storages/StorageFile.cpp:1429: DB::StorageFileSource::generate() @ 0x0000000038416da3 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:53:13.789800 [ 2085 ] {b766c2c4-ca16-4005-be4f-b958ba1ab0a1} Context: Server has databases (for example `test_ma5xkj47_3`) with Ordinary engine, which was deprecated. To convert this database to the new Atomic engine, create a flag /var/lib/clickhouse/flags/convert_ordinary_to_atomic and make sure that ClickHouse has write permission for it. Example: sudo touch '/var/lib/clickhouse/flags/convert_ordinary_to_atomic' && sudo chmod 666 '/var/lib/clickhouse/flags/convert_ordinary_to_atomic' 2025.06.13 08:53:17.126970 [ 24857 ] {51c89cbd-8b42-4de8-9cd7-a371fa2a9f0c} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 2 (error): error here . Expected one of: Query, Query with output, EXPLAIN, EXPLAIN, SELECT query, possibly with UNION, list of union elements, SELECT query, subquery, possibly with UNION, SELECT subquery, SELECT query, WITH, FROM, SELECT, SHOW CREATE QUOTA query, SHOW CREATE, SHOW [FULL] [TEMPORARY] TABLES|DATABASES|CLUSTERS|CLUSTER|MERGES 'name' [[NOT] [I]LIKE 'str'] [LIMIT expr], SHOW, SHOW COLUMNS query, SHOW ENGINES query, SHOW ENGINES, SHOW FUNCTIONS query, SHOW FUNCTIONS, SHOW INDEXES query, SHOW SETTING query, SHOW SETTING, EXISTS or SHOW CREATE query, EXISTS, DESCRIBE FILESYSTEM CACHE query, DESCRIBE, DESC, DESCRIBE query, SHOW PROCESSLIST query, SHOW PROCESSLIST, CREATE TABLE or ATTACH TABLE query, CREATE, ATTACH, REPLACE, CREATE DATABASE query, CREATE VIEW query, CREATE DICTIONARY, CREATE LIVE VIEW query, CREATE WINDOW VIEW query, ALTER query, ALTER TABLE, ALTER TEMPORARY TABLE, ALTER DATABASE, RENAME query, RENAME DATABASE, RENAME TABLE, EXCHANGE TABLES, RENAME DICTIONARY, EXCHANGE DICTIONARIES, RENAME, DROP query, DROP, DETACH, TRUNCATE, UNDROP query, UNDROP, CHECK ALL TABLES, CHECK TABLE, KILL QUERY query, KILL, OPTIMIZE query, OPTIMIZE TABLE, WATCH query, WATCH, SHOW ACCESS query, SHOW ACCESS, ShowAccessEntitiesQuery, SHOW GRANTS query, SHOW GRANTS, SHOW PRIVILEGES query, SHOW PRIVILEGES, BACKUP or RESTORE query, BACKUP, RESTORE, INSERT query, INSERT INTO, USE query, USE, SET ROLE or SET DEFAULT ROLE query, SET ROLE DEFAULT, SET ROLE, SET DEFAULT ROLE, SET query, SET, SYSTEM query, SYSTEM, CREATE USER or ALTER USER query, ALTER USER, CREATE USER, CREATE ROLE or ALTER ROLE query, ALTER ROLE, CREATE ROLE, CREATE QUOTA or ALTER QUOTA query, ALTER QUOTA, CREATE QUOTA, CREATE ROW POLICY or ALTER ROW POLICY query, ALTER POLICY, ALTER ROW POLICY, CREATE POLICY, CREATE ROW POLICY, CREATE SETTINGS PROFILE or ALTER SETTINGS PROFILE query, ALTER SETTINGS PROFILE, ALTER PROFILE, CREATE SETTINGS PROFILE, CREATE PROFILE, CREATE FUNCTION query, DROP FUNCTION query, CREATE WORKLOAD query, DROP WORKLOAD query, CREATE RESOURCE query, DROP RESOURCE query, CREATE NAMED COLLECTION, DROP NAMED COLLECTION query, Alter NAMED COLLECTION query, ALTER, CREATE INDEX query, DROP INDEX query, DROP access entity query, MOVE access entity query, MOVE, GRANT or REVOKE query, REVOKE, GRANT, CHECK GRANT, CHECK GRANT, EXTERNAL DDL query, EXTERNAL DDL FROM, TCL query, BEGIN TRANSACTION, START TRANSACTION, COMMIT, ROLLBACK, SET TRANSACTION SNAPSHOT, Delete query, DELETE. (SYNTAX_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:59828) (in query: error here ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008c167de 3. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003e1c5d8a 4. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003e1c5ed1 5. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033726084 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 7. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:53:17.129417 [ 24857 ] {51c89cbd-8b42-4de8-9cd7-a371fa2a9f0c} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 2 (error): error here . Expected one of: Query, Query with output, EXPLAIN, EXPLAIN, SELECT query, possibly with UNION, list of union elements, SELECT query, subquery, possibly with UNION, SELECT subquery, SELECT query, WITH, FROM, SELECT, SHOW CREATE QUOTA query, SHOW CREATE, SHOW [FULL] [TEMPORARY] TABLES|DATABASES|CLUSTERS|CLUSTER|MERGES 'name' [[NOT] [I]LIKE 'str'] [LIMIT expr], SHOW, SHOW COLUMNS query, SHOW ENGINES query, SHOW ENGINES, SHOW FUNCTIONS query, SHOW FUNCTIONS, SHOW INDEXES query, SHOW SETTING query, SHOW SETTING, EXISTS or SHOW CREATE query, EXISTS, DESCRIBE FILESYSTEM CACHE query, DESCRIBE, DESC, DESCRIBE query, SHOW PROCESSLIST query, SHOW PROCESSLIST, CREATE TABLE or ATTACH TABLE query, CREATE, ATTACH, REPLACE, CREATE DATABASE query, CREATE VIEW query, CREATE DICTIONARY, CREATE LIVE VIEW query, CREATE WINDOW VIEW query, ALTER query, ALTER TABLE, ALTER TEMPORARY TABLE, ALTER DATABASE, RENAME query, RENAME DATABASE, RENAME TABLE, EXCHANGE TABLES, RENAME DICTIONARY, EXCHANGE DICTIONARIES, RENAME, DROP query, DROP, DETACH, TRUNCATE, UNDROP query, UNDROP, CHECK ALL TABLES, CHECK TABLE, KILL QUERY query, KILL, OPTIMIZE query, OPTIMIZE TABLE, WATCH query, WATCH, SHOW ACCESS query, SHOW ACCESS, ShowAccessEntitiesQuery, SHOW GRANTS query, SHOW GRANTS, SHOW PRIVILEGES query, SHOW PRIVILEGES, BACKUP or RESTORE query, BACKUP, RESTORE, INSERT query, INSERT INTO, USE query, USE, SET ROLE or SET DEFAULT ROLE query, SET ROLE DEFAULT, SET ROLE, SET DEFAULT ROLE, SET query, SET, SYSTEM query, SYSTEM, CREATE USER or ALTER USER query, ALTER USER, CREATE USER, CREATE ROLE or ALTER ROLE query, ALTER ROLE, CREATE ROLE, CREATE QUOTA or ALTER QUOTA query, ALTER QUOTA, CREATE QUOTA, CREATE ROW POLICY or ALTER ROW POLICY query, ALTER POLICY, ALTER ROW POLICY, CREATE POLICY, CREATE ROW POLICY, CREATE SETTINGS PROFILE or ALTER SETTINGS PROFILE query, ALTER SETTINGS PROFILE, ALTER PROFILE, CREATE SETTINGS PROFILE, CREATE PROFILE, CREATE FUNCTION query, DROP FUNCTION query, CREATE WORKLOAD query, DROP WORKLOAD query, CREATE RESOURCE query, DROP RESOURCE query, CREATE NAMED COLLECTION, DROP NAMED COLLECTION query, Alter NAMED COLLECTION query, ALTER, CREATE INDEX query, DROP INDEX query, DROP access entity query, MOVE access entity query, MOVE, GRANT or REVOKE query, REVOKE, GRANT, CHECK GRANT, CHECK GRANT, EXTERNAL DDL query, EXTERNAL DDL FROM, TCL query, BEGIN TRANSACTION, START TRANSACTION, COMMIT, ROLLBACK, SET TRANSACTION SNAPSHOT, Delete query, DELETE. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008c167de 3. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003e1c5d8a 4. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003e1c5ed1 5. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033726084 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 7. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:53:28.772581 [ 2135 ] {d0c3d238-f370-44ae-93c8-176a4385e76d} executeQuery: Code: 36. DB::Exception: Window 'w' is already defined. In scope SELECT count(*) OVER w FROM users WINDOW w AS (ORDER BY uid ASC), w AS (ORDER BY name ASC). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56032) (comment: 03149_analyzer_window_redefinition.sql) (query 5, line 7) (in query: SELECT count(*) OVER w FROM users WINDOW w AS (ORDER BY uid), w AS(ORDER BY name);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000030311f64 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 2025.06.13 08:53:28.785652 [ 2135 ] {} TCPHandler: Code: 36. DB::Exception: Window 'w' is already defined. In scope SELECT count(*) OVER w FROM users WINDOW w AS (ORDER BY uid ASC), w AS (ORDER BY name ASC). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000030311f64 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 2025.06.13 08:53:42.309146 [ 24858 ] {0745d3f8-d2a8-4648-86b3-2433095b59a1} executeQuery: Code: 117. DB::Exception: Incorrect arguments h3Index: 72057594037927935, k: 10, error: 2: In scope SELECT h3HexRing(72057594037927935, toUInt16(10)). (INCORRECT_DATA) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39452) (comment: 01659_h3_buffer_overflow.sql) (query 9, line 13) (in query: SELECT h3HexRing(0xFFFFFFFFFFFFFF, toUInt16(10)) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, int const&, unsigned int&) @ 0x000000001152e8f7 4. DB::(anonymous namespace)::FunctionH3HexRing::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001152d7a4 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 08:53:42.329518 [ 24858 ] {} TCPHandler: Code: 117. DB::Exception: Incorrect arguments h3Index: 72057594037927935, k: 10, error: 2: In scope SELECT h3HexRing(72057594037927935, toUInt16(10)). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, int const&, unsigned int&) @ 0x000000001152e8f7 4. DB::(anonymous namespace)::FunctionH3HexRing::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001152d7a4 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 08:53:42.381925 [ 24858 ] {f5911bb7-9a47-4847-b0c9-e3edffe3d3f5} executeQuery: Code: 117. DB::Exception: Incorrect arguments h3Index: 72057594037927935, k: 10000, error: 2: In scope SELECT h3HexRing(72057594037927935, toUInt16(10000)). (INCORRECT_DATA) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39452) (comment: 01659_h3_buffer_overflow.sql) (query 10, line 14) (in query: SELECT h3HexRing(0xFFFFFFFFFFFFFF, toUInt16(10000)) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, int const&, unsigned int&) @ 0x000000001152e8f7 4. DB::(anonymous namespace)::FunctionH3HexRing::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001152d7a4 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 08:53:42.414399 [ 24858 ] {} TCPHandler: Code: 117. DB::Exception: Incorrect arguments h3Index: 72057594037927935, k: 10000, error: 2: In scope SELECT h3HexRing(72057594037927935, toUInt16(10000)). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, int const&, unsigned int&) @ 0x000000001152e8f7 4. DB::(anonymous namespace)::FunctionH3HexRing::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001152d7a4 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 08:53:44.915876 [ 24842 ] {5a10a256-bc8f-48a1-8a28-005c16ee1ec0} executeQuery: Code: 319. DB::Exception: Unknown quorum status. The data was inserted in the local replica but we could not verify quorum. Reason: Timeout while waiting for quorum. (UNKNOWN_STATUS_OF_INSERT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40020) (comment: 00732_quorum_insert_select_with_old_data_and_without_quorum_zookeeper_long.sql) (query 14, line 26) (in query: INSERT INTO quorum2 VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1270: DB::ReplicatedMergeTreeSinkImpl::waitForQuorum(std::shared_ptr const&, String const&, String const&, int, int, unsigned long) const @ 0x000000003a2cfe7b 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1200: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()::operator()() const @ 0x000000003a317b52 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()&&) @ 0x000000003a31747f 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a2c9762 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a29d717 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000003a2c67d4 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e76f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d33c 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b10197a 17. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003adbc219 18. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x000000003ad8e9f8 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:53:44.951150 [ 24842 ] {} TCPHandler: Code: 319. DB::Exception: Unknown quorum status. The data was inserted in the local replica but we could not verify quorum. Reason: Timeout while waiting for quorum. (UNKNOWN_STATUS_OF_INSERT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1270: DB::ReplicatedMergeTreeSinkImpl::waitForQuorum(std::shared_ptr const&, String const&, String const&, int, int, unsigned long) const @ 0x000000003a2cfe7b 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1200: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()::operator()() const @ 0x000000003a317b52 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()&&) @ 0x000000003a31747f 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a2c9762 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a29d717 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000003a2c67d4 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e76f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d33c 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b10197a 17. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003adbc219 18. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x000000003ad8e9f8 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:53:51.450690 [ 15838 ] {c2601804-002a-460a-991a-bc4b36635a89} executeQuery: Code: 131. DB::Exception: String size is too big (2147483648), maximum: 2147483647: while executing 'FUNCTION CAST(concat(_CAST('ÿÿÿ'_String, 'String'_String), randomString(100500_UInt32)) :: 2, 'AggregateFunction(max, String)'_String :: 3) -> CAST(concat(_CAST('ÿÿÿ'_String, 'String'_String), randomString(100500_UInt32)), 'AggregateFunction(max, String)'_String) AggregateFunction(max, String) : 4'. (TOO_LARGE_STRING_SIZE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49898) (comment: 02477_single_value_data_string_regression.sql) (query 26, line 93) (in query: SELECT '2^31-1', maxMerge(x) from (select CAST(unhex('ffffff7f') || randomString(100500), 'AggregateFunction(max, String)') as x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int&, unsigned int const&) @ 0x0000000022ebe22d 4. ./build_docker/./src/AggregateFunctions/SingleValueData.cpp:1135: DB::SingleValueDataString::allocateLargeDataIfNeeded(unsigned int, DB::Arena*) @ 0x0000000022e4d39a 5. ./build_docker/./src/AggregateFunctions/SingleValueData.cpp:1213: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, DB::Arena*) @ 0x0000000022e4e25e 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:135: DB::(anonymous namespace)::AggregateFunctionMinMax::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000022e457af 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f4f6b11 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f4f72bc 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c1f7b0d 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c1f4e39 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c7cf77c 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 17. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:53:51.459269 [ 15838 ] {} TCPHandler: Code: 131. DB::Exception: String size is too big (2147483648), maximum: 2147483647: while executing 'FUNCTION CAST(concat(_CAST('ÿÿÿ'_String, 'String'_String), randomString(100500_UInt32)) :: 2, 'AggregateFunction(max, String)'_String :: 3) -> CAST(concat(_CAST('ÿÿÿ'_String, 'String'_String), randomString(100500_UInt32)), 'AggregateFunction(max, String)'_String) AggregateFunction(max, String) : 4'. (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int&, unsigned int const&) @ 0x0000000022ebe22d 4. ./build_docker/./src/AggregateFunctions/SingleValueData.cpp:1135: DB::SingleValueDataString::allocateLargeDataIfNeeded(unsigned int, DB::Arena*) @ 0x0000000022e4d39a 5. ./build_docker/./src/AggregateFunctions/SingleValueData.cpp:1213: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, DB::Arena*) @ 0x0000000022e4e25e 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:135: DB::(anonymous namespace)::AggregateFunctionMinMax::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000022e457af 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f4f6b11 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f4f72bc 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c1f7b0d 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c1f4e39 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c7cf77c 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 17. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:53:51.468171 [ 15875 ] {41d9da76-7fab-4712-8a78-1c7c48b05f93} executeQuery: Code: 42. DB::Exception: Number of arguments for function not doesn't match: passed 3, should be 1: In scope SELECT not(1, 1, 1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49918) (comment: 03168_inconsistent_ast_formatting.sql) (query 8, line 15) (in query: SELECT NOT (1, 1, 1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:53:51.472240 [ 15875 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function not doesn't match: passed 3, should be 1: In scope SELECT not(1, 1, 1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:53:51.935941 [ 15875 ] {e9179c4e-ea98-4d06-bdb5-4a93fbd36f4b} executeQuery: Code: 43. DB::Exception: Illegal type (Tuple(UInt8)) of argument of function not: In scope SELECT NOT tuple(1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49918) (comment: 03168_inconsistent_ast_formatting.sql) (query 12, line 20) (in query: SELECT NOT ((1,));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::FunctionsLogicalDetail::FunctionUnaryLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002c16f1b8 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:53:51.940138 [ 15875 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type (Tuple(UInt8)) of argument of function not: In scope SELECT NOT tuple(1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::FunctionsLogicalDetail::FunctionUnaryLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002c16f1b8 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:53:51.961744 [ 15875 ] {8295984a-4cb5-4da3-a76d-b3c2c19732f2} executeQuery: Code: 43. DB::Exception: Illegal type (Tuple(UInt8)) of argument of function not: In scope SELECT NOT tuple(1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49918) (comment: 03168_inconsistent_ast_formatting.sql) (query 13, line 21) (in query: SELECT NOT tuple(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::FunctionsLogicalDetail::FunctionUnaryLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002c16f1b8 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:53:51.965745 [ 15875 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type (Tuple(UInt8)) of argument of function not: In scope SELECT NOT tuple(1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::FunctionsLogicalDetail::FunctionUnaryLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002c16f1b8 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:53:52.208525 [ 15875 ] {29f643ac-a3c9-44fd-a085-69d2f69118b5} executeQuery: Code: 43. DB::Exception: Illegal type (Tuple(UInt8, UInt8, UInt8)) of argument of function not: In scope SELECT NOT ((1, 1, 1)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49918) (comment: 03168_inconsistent_ast_formatting.sql) (query 18, line 27) (in query: SELECT NOT ((1, 1, 1));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::FunctionsLogicalDetail::FunctionUnaryLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002c16f1b8 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:53:52.212172 [ 15875 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type (Tuple(UInt8, UInt8, UInt8)) of argument of function not: In scope SELECT NOT ((1, 1, 1)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::FunctionsLogicalDetail::FunctionUnaryLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002c16f1b8 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:53:52.519954 [ 15875 ] {837205b2-d6d0-435b-a6ab-987638fced28} executeQuery: Code: 43. DB::Exception: Illegal type (Array(UInt8)) of argument of function not: In scope SELECT NOT [1]. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49918) (comment: 03168_inconsistent_ast_formatting.sql) (query 24, line 34) (in query: SELECT NOT [1];), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::FunctionsLogicalDetail::FunctionUnaryLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002c16f1b8 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:53:52.525223 [ 15875 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type (Array(UInt8)) of argument of function not: In scope SELECT NOT [1]. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::FunctionsLogicalDetail::FunctionUnaryLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002c16f1b8 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:53:52.557005 [ 15875 ] {9747e720-9662-4745-9f94-f722ef4a24d8} executeQuery: Code: 43. DB::Exception: Illegal type (Array(UInt8)) of argument of function not: In scope SELECT NOT [1]. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49918) (comment: 03168_inconsistent_ast_formatting.sql) (query 25, line 35) (in query: SELECT NOT [(1)];), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::FunctionsLogicalDetail::FunctionUnaryLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002c16f1b8 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:53:52.561668 [ 15875 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type (Array(UInt8)) of argument of function not: In scope SELECT NOT [1]. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::FunctionsLogicalDetail::FunctionUnaryLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002c16f1b8 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:53:53.376399 [ 15838 ] {292b8e6f-6ea6-42f3-84d7-a319559a2e17} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 100500. Bytes expected: 2147483646.: while executing 'FUNCTION CAST(concat(_CAST('þÿÿ'_String, 'String'_String), randomString(100500_UInt32)) :: 2, 'AggregateFunction(max, String)'_String :: 3) -> CAST(concat(_CAST('þÿÿ'_String, 'String'_String), randomString(100500_UInt32)), 'AggregateFunction(max, String)'_String) AggregateFunction(max, String) : 4'. (CANNOT_READ_ALL_DATA) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49898) (comment: 02477_single_value_data_string_regression.sql) (query 27, line 95) (in query: SELECT '2^31-2', maxMerge(x) from (select CAST(unhex('feffff7f') || randomString(100500), 'AggregateFunction(max, String)') as x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f0678cd 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f879ba7 5. ./build_docker/./src/AggregateFunctions/SingleValueData.cpp:1215: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, DB::Arena*) @ 0x0000000022e4e29d 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:135: DB::(anonymous namespace)::AggregateFunctionMinMax::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000022e457af 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f4f6b11 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f4f72bc 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c1f7b0d 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c1f4e39 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c7cf77c 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 17. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:53:53.385328 [ 15838 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 100500. Bytes expected: 2147483646.: while executing 'FUNCTION CAST(concat(_CAST('þÿÿ'_String, 'String'_String), randomString(100500_UInt32)) :: 2, 'AggregateFunction(max, String)'_String :: 3) -> CAST(concat(_CAST('þÿÿ'_String, 'String'_String), randomString(100500_UInt32)), 'AggregateFunction(max, String)'_String) AggregateFunction(max, String) : 4'. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f0678cd 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f879ba7 5. ./build_docker/./src/AggregateFunctions/SingleValueData.cpp:1215: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, DB::Arena*) @ 0x0000000022e4e29d 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:135: DB::(anonymous namespace)::AggregateFunctionMinMax::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000022e457af 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f4f6b11 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f4f72bc 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c1f7b0d 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c1f4e39 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c7cf77c 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 17. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:53:53.421625 [ 15875 ] {f2d7a518-7a9a-4b22-9411-bde70865c24b} executeQuery: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument of function negate: In scope SELECT -[1]. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49918) (comment: 03168_inconsistent_ast_formatting.sql) (query 32, line 43) (in query: SELECT -[1];), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::FunctionUnaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x00000000173913ab 5. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001735b4e3 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:53:53.426101 [ 15875 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument of function negate: In scope SELECT -[1]. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::FunctionUnaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x00000000173913ab 5. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001735b4e3 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:53:53.451314 [ 15875 ] {c8da7c24-88a4-47ce-b65d-9b7fa551015d} executeQuery: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument of function negate: In scope SELECT -[1]. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49918) (comment: 03168_inconsistent_ast_formatting.sql) (query 33, line 44) (in query: SELECT -[(1)];), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::FunctionUnaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x00000000173913ab 5. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001735b4e3 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:53:53.455444 [ 15875 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument of function negate: In scope SELECT -[1]. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::FunctionUnaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x00000000173913ab 5. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001735b4e3 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:53:54.689395 [ 24861 ] {29aff0b8-ff62-482c-89a3-f53278a8fe31} executeQuery: Code: 701. DB::Exception: Requested cluster 'not_exists' not found. (CLUSTER_DOESNT_EXIST) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59264) (comment: 03215_analyzer_replace_with_dummy_tables.sql) (query 2, line 3) (in query: SELECT 1 FROM ( SELECT number IN ( SELECT number FROM view( SELECT number FROM numbers(1) ) ) FROM t ) SETTINGS allow_experimental_parallel_reading_from_replicas = 1, cluster_for_parallel_replicas='not_exists', max_parallel_replicas = 2, allow_experimental_analyzer = 1, parallel_replicas_for_non_replicated_merge_tree = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Interpreters/Context.cpp:4481: DB::Context::getCluster(String const&) const @ 0x000000003172ea01 5. ./build_docker/./src/Interpreters/Context.cpp:6316: DB::Context::getClusterForParallelReplicas() const @ 0x0000000031762daf 6. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:488: DB::ClusterProxy::executeQueryWithParallelReplicas(DB::QueryPlan&, DB::StorageID const&, DB::Block const&, DB::QueryProcessingStage::Enum, std::shared_ptr const&, std::shared_ptr, std::shared_ptr> const>, std::unique_ptr>) @ 0x0000000036f2bf14 7. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:508: DB::buildQueryPlanForParallelReplicas(DB::QueryNode const&, std::shared_ptr const&, std::shared_ptr> const>) @ 0x0000000032b3c0e3 8. ./build_docker/./src/Planner/Planner.cpp:1563: DB::Planner::buildPlanForQueryNode() @ 0x0000000032afcd2f 9. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:53:54.695485 [ 24861 ] {} TCPHandler: Code: 701. DB::Exception: Requested cluster 'not_exists' not found. (CLUSTER_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Interpreters/Context.cpp:4481: DB::Context::getCluster(String const&) const @ 0x000000003172ea01 5. ./build_docker/./src/Interpreters/Context.cpp:6316: DB::Context::getClusterForParallelReplicas() const @ 0x0000000031762daf 6. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:488: DB::ClusterProxy::executeQueryWithParallelReplicas(DB::QueryPlan&, DB::StorageID const&, DB::Block const&, DB::QueryProcessingStage::Enum, std::shared_ptr const&, std::shared_ptr, std::shared_ptr> const>, std::unique_ptr>) @ 0x0000000036f2bf14 7. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:508: DB::buildQueryPlanForParallelReplicas(DB::QueryNode const&, std::shared_ptr const&, std::shared_ptr> const>) @ 0x0000000032b3c0e3 8. ./build_docker/./src/Planner/Planner.cpp:1563: DB::Planner::buildPlanForQueryNode() @ 0x0000000032afcd2f 9. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:53:55.466562 [ 15838 ] {4b185ee5-6653-40be-a293-77809efc932c} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 100500. Bytes expected: 1073741824.: while executing 'FUNCTION CAST(concat(_CAST('\0\0\0@'_String, 'String'_String), randomString(100500_UInt32)) :: 2, 'AggregateFunction(max, String)'_String :: 3) -> CAST(concat(_CAST('\0\0\0@'_String, 'String'_String), randomString(100500_UInt32)), 'AggregateFunction(max, String)'_String) AggregateFunction(max, String) : 4'. (CANNOT_READ_ALL_DATA) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49898) (comment: 02477_single_value_data_string_regression.sql) (query 28, line 97) (in query: SELECT '2^30', maxMerge(x) from (select CAST(unhex('00000040') || randomString(100500), 'AggregateFunction(max, String)') as x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f0678cd 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f879ba7 5. ./build_docker/./src/AggregateFunctions/SingleValueData.cpp:1215: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, DB::Arena*) @ 0x0000000022e4e29d 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:135: DB::(anonymous namespace)::AggregateFunctionMinMax::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000022e457af 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f4f6b11 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f4f72bc 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c1f7b0d 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c1f4e39 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c7cf77c 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 17. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:53:55.483177 [ 15838 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 100500. Bytes expected: 1073741824.: while executing 'FUNCTION CAST(concat(_CAST('\0\0\0@'_String, 'String'_String), randomString(100500_UInt32)) :: 2, 'AggregateFunction(max, String)'_String :: 3) -> CAST(concat(_CAST('\0\0\0@'_String, 'String'_String), randomString(100500_UInt32)), 'AggregateFunction(max, String)'_String) AggregateFunction(max, String) : 4'. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f0678cd 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f879ba7 5. ./build_docker/./src/AggregateFunctions/SingleValueData.cpp:1215: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, DB::Arena*) @ 0x0000000022e4e29d 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:135: DB::(anonymous namespace)::AggregateFunctionMinMax::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000022e457af 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f4f6b11 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f4f72bc 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c1f7b0d 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c1f4e39 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c7cf77c 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 17. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:53:57.524486 [ 15838 ] {b01ffa8f-47d9-4d5c-8195-d10ebf453324} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 100500. Bytes expected: 1073741825.: while executing 'FUNCTION CAST(concat(_CAST('\0\0@'_String, 'String'_String), randomString(100500_UInt32)) :: 2, 'AggregateFunction(max, String)'_String :: 3) -> CAST(concat(_CAST('\0\0@'_String, 'String'_String), randomString(100500_UInt32)), 'AggregateFunction(max, String)'_String) AggregateFunction(max, String) : 4'. (CANNOT_READ_ALL_DATA) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49898) (comment: 02477_single_value_data_string_regression.sql) (query 29, line 98) (in query: SELECT '2^30+1', maxMerge(x) from (select CAST(unhex('01000040') || randomString(100500), 'AggregateFunction(max, String)') as x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f0678cd 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f879ba7 5. ./build_docker/./src/AggregateFunctions/SingleValueData.cpp:1215: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, DB::Arena*) @ 0x0000000022e4e29d 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:135: DB::(anonymous namespace)::AggregateFunctionMinMax::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000022e457af 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f4f6b11 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f4f72bc 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c1f7b0d 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c1f4e39 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c7cf77c 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 17. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:53:57.536555 [ 15838 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 100500. Bytes expected: 1073741825.: while executing 'FUNCTION CAST(concat(_CAST('\0\0@'_String, 'String'_String), randomString(100500_UInt32)) :: 2, 'AggregateFunction(max, String)'_String :: 3) -> CAST(concat(_CAST('\0\0@'_String, 'String'_String), randomString(100500_UInt32)), 'AggregateFunction(max, String)'_String) AggregateFunction(max, String) : 4'. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f0678cd 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f879ba7 5. ./build_docker/./src/AggregateFunctions/SingleValueData.cpp:1215: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, DB::Arena*) @ 0x0000000022e4e29d 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:135: DB::(anonymous namespace)::AggregateFunctionMinMax::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000022e457af 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f4f6b11 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f4f72bc 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c1f7b0d 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c1f4e39 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c7cf77c 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 17. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:53:58.662147 [ 15838 ] {16fba552-df2c-4b7c-98ed-a0a6a9a8e765} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 100500. Bytes expected: 1073741823.: while executing 'FUNCTION CAST(concat(_CAST('ÿÿÿ?'_String, 'String'_String), randomString(100500_UInt32)) :: 2, 'AggregateFunction(max, String)'_String :: 3) -> CAST(concat(_CAST('ÿÿÿ?'_String, 'String'_String), randomString(100500_UInt32)), 'AggregateFunction(max, String)'_String) AggregateFunction(max, String) : 4'. (CANNOT_READ_ALL_DATA) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49898) (comment: 02477_single_value_data_string_regression.sql) (query 30, line 100) (in query: SELECT '2^30-1', maxMerge(x) from (select CAST(unhex('ffffff3f') || randomString(100500), 'AggregateFunction(max, String)') as x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f0678cd 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f879ba7 5. ./build_docker/./src/AggregateFunctions/SingleValueData.cpp:1215: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, DB::Arena*) @ 0x0000000022e4e29d 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:135: DB::(anonymous namespace)::AggregateFunctionMinMax::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000022e457af 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f4f6b11 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f4f72bc 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c1f7b0d 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c1f4e39 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c7cf77c 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 17. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:53:58.674595 [ 15838 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 100500. Bytes expected: 1073741823.: while executing 'FUNCTION CAST(concat(_CAST('ÿÿÿ?'_String, 'String'_String), randomString(100500_UInt32)) :: 2, 'AggregateFunction(max, String)'_String :: 3) -> CAST(concat(_CAST('ÿÿÿ?'_String, 'String'_String), randomString(100500_UInt32)), 'AggregateFunction(max, String)'_String) AggregateFunction(max, String) : 4'. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f0678cd 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f879ba7 5. ./build_docker/./src/AggregateFunctions/SingleValueData.cpp:1215: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, DB::Arena*) @ 0x0000000022e4e29d 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:135: DB::(anonymous namespace)::AggregateFunctionMinMax::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000022e457af 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f4f6b11 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f4f72bc 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c1f7b0d 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c1f4e39 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c7cf77c 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 17. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:53:59.209516 [ 4780 ] {fd05b25d-0d0f-42d9-bbeb-28cd87d9634e} BackupsWorker: Failed to restore from backup Null: Code: 599. DB::Exception: Backup Null not found (cannot restore from Null). (BACKUP_NOT_FOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Backups/BackupIO_Null.cpp:97: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl[abi:ne190107] (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000002e80eb07 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002e7a3624 6. ./build_docker/./src/Backups/BackupsWorker.cpp:874: DB::BackupsWorker::openBackupForReading(DB::BackupInfo const&, DB::RestoreSettings const&, std::shared_ptr const&) const @ 0x000000002e771126 7. ./build_docker/./src/Backups/BackupsWorker.cpp:896: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&) @ 0x000000002e7730c4 8. ./build_docker/./src/Backups/BackupsWorker.cpp:793: DB::BackupsWorker::RestoreStarter::doRestore() @ 0x000000002e799d6c 9. ./build_docker/./src/Backups/BackupsWorker.cpp:840: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002e784e7e 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d800601 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::__packaged_task_func (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority)::'lambda'(), std::allocator (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority)::'lambda'()>, void ()>::operator()() @ 0x000000002d80044d 12. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002d800cdd 13. ./src/Common/threadPoolCallbackRunner.h:52: void std::__function::__policy_invoker::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority)::'lambda0'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d800b4e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d7fe781 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d7fe1a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002e761936 7. ./build_docker/./src/Backups/BackupsWorker.cpp:335: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e760298 8. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x00000000338e9989 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:53:59.212014 [ 15837 ] {fd05b25d-0d0f-42d9-bbeb-28cd87d9634e} executeQuery: Code: 599. DB::Exception: Backup Null not found (cannot restore from Null). (BACKUP_NOT_FOUND) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59350) (comment: 03286_backup_to_null.sql) (query 6, line 10) (in query: RESTORE TABLE t1 FROM Null FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Backups/BackupIO_Null.cpp:97: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl[abi:ne190107] (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000002e80eb07 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002e7a3624 6. ./build_docker/./src/Backups/BackupsWorker.cpp:874: DB::BackupsWorker::openBackupForReading(DB::BackupInfo const&, DB::RestoreSettings const&, std::shared_ptr const&) const @ 0x000000002e771126 7. ./build_docker/./src/Backups/BackupsWorker.cpp:896: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&) @ 0x000000002e7730c4 8. ./build_docker/./src/Backups/BackupsWorker.cpp:793: DB::BackupsWorker::RestoreStarter::doRestore() @ 0x000000002e799d6c 9. ./build_docker/./src/Backups/BackupsWorker.cpp:840: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002e784e7e 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d800601 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::__packaged_task_func (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority)::'lambda'(), std::allocator (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority)::'lambda'()>, void ()>::operator()() @ 0x000000002d80044d 12. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002d800cdd 13. ./src/Common/threadPoolCallbackRunner.h:52: void std::__function::__policy_invoker::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority)::'lambda0'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d800b4e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:53:59.217117 [ 15837 ] {} TCPHandler: Code: 599. DB::Exception: Backup Null not found (cannot restore from Null). (BACKUP_NOT_FOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Backups/BackupIO_Null.cpp:97: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl[abi:ne190107] (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000002e80eb07 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002e7a3624 6. ./build_docker/./src/Backups/BackupsWorker.cpp:874: DB::BackupsWorker::openBackupForReading(DB::BackupInfo const&, DB::RestoreSettings const&, std::shared_ptr const&) const @ 0x000000002e771126 7. ./build_docker/./src/Backups/BackupsWorker.cpp:896: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&) @ 0x000000002e7730c4 8. ./build_docker/./src/Backups/BackupsWorker.cpp:793: DB::BackupsWorker::RestoreStarter::doRestore() @ 0x000000002e799d6c 9. ./build_docker/./src/Backups/BackupsWorker.cpp:840: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002e784e7e 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d800601 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::__packaged_task_func (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority)::'lambda'(), std::allocator (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority)::'lambda'()>, void ()>::operator()() @ 0x000000002d80044d 12. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002d800cdd 13. ./src/Common/threadPoolCallbackRunner.h:52: void std::__function::__policy_invoker::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority)::'lambda0'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d800b4e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d7fe781 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d7fe1a0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002e761936 7. ./build_docker/./src/Backups/BackupsWorker.cpp:335: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e760298 8. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x00000000338e9989 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:53:59.448037 [ 15838 ] {0857dfc0-38f3-46ee-94db-981ea9224837} executeQuery: Code: 117. DB::Exception: Invalid state of the aggregate function argMax: has_value (true) != has_result (false): In scope SELECT 'fuzz1', finalizeAggregation(CAST(unhex('3000000\0303132333435363738393031323334353637383930313233343536373839303132333435363738393031323334353600010000000000000000'), 'AggregateFunction(argMax, String, UInt64)')). (INCORRECT_DATA) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49898) (comment: 02477_single_value_data_string_regression.sql) (query 33, line 106) (in query: SELECT 'fuzz1', finalizeAggregation(CAST(unhex('3000000\0303132333435363738393031323334353637383930313233343536373839303132333435363738393031323334353600010000000000000000'), 'AggregateFunction(argMax, String, UInt64)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, bool&&, bool&&) @ 0x00000000233e1b37 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionsArgMinArgMax.cpp:235: DB::(anonymous namespace)::AggregateFunctionArgMinMax>, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000233907c6 5. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f4f6b11 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f4f72bc 7. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c1f7b0d 8. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c1f4e39 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c7cf77c 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008bec782 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 2025.06.13 08:53:59.452319 [ 15838 ] {} TCPHandler: Code: 117. DB::Exception: Invalid state of the aggregate function argMax: has_value (true) != has_result (false): In scope SELECT 'fuzz1', finalizeAggregation(CAST(unhex('3000000\0303132333435363738393031323334353637383930313233343536373839303132333435363738393031323334353600010000000000000000'), 'AggregateFunction(argMax, String, UInt64)')). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, bool&&, bool&&) @ 0x00000000233e1b37 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionsArgMinArgMax.cpp:235: DB::(anonymous namespace)::AggregateFunctionArgMinMax>, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000233907c6 5. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f4f6b11 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f4f72bc 7. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c1f7b0d 8. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c1f4e39 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c7cf77c 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008bec782 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 2025.06.13 08:53:59.571139 [ 15838 ] {5ec7ca27-93c5-4af8-85c1-2ce8b60a5658} executeQuery: Code: 117. DB::Exception: Invalid state of the aggregate function argMax: has_value (false) != has_result (true): In scope SELECT 'fuzz3', finalizeAggregation(CAST(unhex(concat('04000000', '30313233', '00', 'ffffffffffffffff')), 'AggregateFunction(argMax, String, UInt64)')) AS x, length(x). (INCORRECT_DATA) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49898) (comment: 02477_single_value_data_string_regression.sql) (query 35, line 108) (in query: SELECT 'fuzz3', finalizeAggregation(CAST(unhex('04000000' || '30313233' || '00' || 'ffffffffffffffff'), 'AggregateFunction(argMax, String, UInt64)')) as x, length(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, bool&&, bool&&) @ 0x00000000233e1b37 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionsArgMinArgMax.cpp:235: DB::(anonymous namespace)::AggregateFunctionArgMinMax>, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000233907c6 5. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f4f6b11 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f4f72bc 7. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c1f7b0d 8. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c1f4e39 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c7cf77c 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008bec782 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 2025.06.13 08:53:59.575633 [ 15838 ] {} TCPHandler: Code: 117. DB::Exception: Invalid state of the aggregate function argMax: has_value (false) != has_result (true): In scope SELECT 'fuzz3', finalizeAggregation(CAST(unhex(concat('04000000', '30313233', '00', 'ffffffffffffffff')), 'AggregateFunction(argMax, String, UInt64)')) AS x, length(x). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, bool&&, bool&&) @ 0x00000000233e1b37 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionsArgMinArgMax.cpp:235: DB::(anonymous namespace)::AggregateFunctionArgMinMax>, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000233907c6 5. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f4f6b11 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f4f72bc 7. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c1f7b0d 8. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c1f4e39 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c7cf77c 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008bec782 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 2025.06.13 08:53:59.610855 [ 15838 ] {d5b85bff-37f1-4a76-b0de-e4851197531c} executeQuery: Code: 117. DB::Exception: Invalid state of the aggregate function argMax: has_value (false) != has_result (true): In scope SELECT 'fuzz4', finalizeAggregation(CAST(unhex(concat('04000000', '30313233', '00')), 'AggregateFunction(argMax, String, UInt64)')) AS x, length(x). (INCORRECT_DATA) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49898) (comment: 02477_single_value_data_string_regression.sql) (query 36, line 109) (in query: SELECT 'fuzz4', finalizeAggregation(CAST(unhex('04000000' || '30313233' || '00'), 'AggregateFunction(argMax, String, UInt64)')) as x, length(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, bool&&, bool&&) @ 0x00000000233e1b37 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionsArgMinArgMax.cpp:235: DB::(anonymous namespace)::AggregateFunctionArgMinMax>, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000233907c6 5. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f4f6b11 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f4f72bc 7. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c1f7b0d 8. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c1f4e39 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c7cf77c 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008bec782 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 2025.06.13 08:53:59.615318 [ 15838 ] {} TCPHandler: Code: 117. DB::Exception: Invalid state of the aggregate function argMax: has_value (false) != has_result (true): In scope SELECT 'fuzz4', finalizeAggregation(CAST(unhex(concat('04000000', '30313233', '00')), 'AggregateFunction(argMax, String, UInt64)')) AS x, length(x). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, bool&&, bool&&) @ 0x00000000233e1b37 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionsArgMinArgMax.cpp:235: DB::(anonymous namespace)::AggregateFunctionArgMinMax>, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000233907c6 5. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f4f6b11 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f4f72bc 7. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c1f7b0d 8. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c1f4e39 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c7cf77c 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008bec782 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 2025.06.13 08:54:00.078402 [ 15838 ] {c7bbfd97-98b1-4ca0-82f4-478480b8fe38} executeQuery: Code: 117. DB::Exception: Invalid state of the aggregate function argMax: has_value (false) != has_result (true): In scope SELECT 'fuzz5', finalizeAggregation(CAST(unhex('0100000000000000000FFFFFFFF0'), 'AggregateFunction(argMax, UInt64, String)')). (INCORRECT_DATA) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49898) (comment: 02477_single_value_data_string_regression.sql) (query 37, line 110) (in query: SELECT 'fuzz5', finalizeAggregation(CAST(unhex('0100000000000000000FFFFFFFF0'), 'AggregateFunction(argMax, UInt64, String)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, bool&&, bool&&) @ 0x00000000233e1b37 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionsArgMinArgMax.cpp:235: DB::(anonymous namespace)::AggregateFunctionArgMinMax, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000233d9423 5. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f4f6b11 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f4f72bc 7. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c1f7b0d 8. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c1f4e39 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c7cf77c 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008bec782 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 2025.06.13 08:54:00.082559 [ 15838 ] {} TCPHandler: Code: 117. DB::Exception: Invalid state of the aggregate function argMax: has_value (false) != has_result (true): In scope SELECT 'fuzz5', finalizeAggregation(CAST(unhex('0100000000000000000FFFFFFFF0'), 'AggregateFunction(argMax, UInt64, String)')). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, bool&&, bool&&) @ 0x00000000233e1b37 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionsArgMinArgMax.cpp:235: DB::(anonymous namespace)::AggregateFunctionArgMinMax, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000233d9423 5. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f4f6b11 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f4f72bc 7. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c1f7b0d 8. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c1f4e39 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c7cf77c 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008bec782 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 2025.06.13 08:54:01.969179 [ 24844 ] {b6d01984-c6b3-448c-95e1-c5120e220f2c} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'overlay'. Expected 3 mandatory arguments and 1 optional argument, got 2 arguments: In scope SELECT overlay('hello', 'world'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59406) (comment: 03205_overlay.sql) (query 2, line 2) (in query: SELECT overlay('hello', 'world');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002c037417 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c030910 5. DB::(anonymous namespace)::FunctionOverlay::getReturnTypeImpl(std::vector> const&) const @ 0x00000000180bd600 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:54:01.973310 [ 24844 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'overlay'. Expected 3 mandatory arguments and 1 optional argument, got 2 arguments: In scope SELECT overlay('hello', 'world'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002c037417 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c030910 5. DB::(anonymous namespace)::FunctionOverlay::getReturnTypeImpl(std::vector> const&) const @ 0x00000000180bd600 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:54:01.998070 [ 24844 ] {6f2ec26e-1348-4ad7-8bca-ddba9c5f4e96} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'overlay'. Expected 3 mandatory arguments and 1 optional argument, got 5 arguments: In scope SELECT overlay('hello', 'world', 2, 3, 'extra'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59406) (comment: 03205_overlay.sql) (query 3, line 3) (in query: SELECT overlay('hello', 'world', 2, 3, 'extra');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002c037417 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c030910 5. DB::(anonymous namespace)::FunctionOverlay::getReturnTypeImpl(std::vector> const&) const @ 0x00000000180bd600 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:54:02.002826 [ 24844 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'overlay'. Expected 3 mandatory arguments and 1 optional argument, got 5 arguments: In scope SELECT overlay('hello', 'world', 2, 3, 'extra'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002c037417 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c030910 5. DB::(anonymous namespace)::FunctionOverlay::getReturnTypeImpl(std::vector> const&) const @ 0x00000000180bd600 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:54:02.119402 [ 9220 ] {f103cdc8-ca59-4bb5-a307-1085654b9d05} executeQuery: Code: 252. DB::Exception: Too many partitions for single INSERT block (more than 1). The limit is controlled by 'max_partitions_per_insert_block' setting. Large number of partitions is a common misconception. It will lead to severe negative performance impact, including slow server startup, slow INSERT queries and slow SELECT queries. Recommended total number of partitions for a table is under 1000..10000. Please note, that partitioning is not intended to speed up SELECT queries (ORDER BY key is sufficient to make range queries fast). Partitions are intended for data manipulation (DROP PARTITION, etc). (TOO_MANY_PARTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59296) (comment: 00930_max_partitions_per_insert_block.sql) (query 9, line 12) (in query: INSERT INTO partitions SELECT * FROM system.numbers LIMIT 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000d04bc6a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:119: DB::MergeTreeDataWriter::splitBlockIntoParts(DB::Block&&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr) @ 0x0000000039b78c95 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:95: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a46af12 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 08:54:02.127370 [ 9220 ] {} TCPHandler: Code: 252. DB::Exception: Too many partitions for single INSERT block (more than 1). The limit is controlled by 'max_partitions_per_insert_block' setting. Large number of partitions is a common misconception. It will lead to severe negative performance impact, including slow server startup, slow INSERT queries and slow SELECT queries. Recommended total number of partitions for a table is under 1000..10000. Please note, that partitioning is not intended to speed up SELECT queries (ORDER BY key is sufficient to make range queries fast). Partitions are intended for data manipulation (DROP PARTITION, etc). (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000d04bc6a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:119: DB::MergeTreeDataWriter::splitBlockIntoParts(DB::Block&&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr) @ 0x0000000039b78c95 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:95: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a46af12 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 08:54:02.291458 [ 24844 ] {6ffa00a5-1d59-46f5-9e9b-e40d8ce79b1b} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'overlay'. Expected: String, got: UInt8: In scope SELECT overlay(123, 'world', 2, 3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59406) (comment: 03205_overlay.sql) (query 4, line 4) (in query: SELECT overlay(123, 'world', 2, 3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c037e87 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c0312c1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c02fb7f 6. DB::(anonymous namespace)::FunctionOverlay::getReturnTypeImpl(std::vector> const&) const @ 0x00000000180bd600 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:54:02.295384 [ 24844 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'overlay'. Expected: String, got: UInt8: In scope SELECT overlay(123, 'world', 2, 3). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c037e87 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c0312c1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c02fb7f 6. DB::(anonymous namespace)::FunctionOverlay::getReturnTypeImpl(std::vector> const&) const @ 0x00000000180bd600 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:54:02.329298 [ 24844 ] {4fe48dd3-ea6f-4732-92fe-6b77264d4f69} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'replace' to function 'overlay'. Expected: String, got: UInt16: In scope SELECT overlay('hello', 456, 2, 3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59406) (comment: 03205_overlay.sql) (query 5, line 5) (in query: SELECT overlay('hello', 456, 2, 3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c037e87 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c0312c1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c02fb7f 6. DB::(anonymous namespace)::FunctionOverlay::getReturnTypeImpl(std::vector> const&) const @ 0x00000000180bd600 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:54:02.334573 [ 24844 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'replace' to function 'overlay'. Expected: String, got: UInt16: In scope SELECT overlay('hello', 456, 2, 3). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c037e87 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c0312c1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c02fb7f 6. DB::(anonymous namespace)::FunctionOverlay::getReturnTypeImpl(std::vector> const&) const @ 0x00000000180bd600 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:54:02.360340 [ 24844 ] {51e6ae5e-00b6-41e6-8939-3181dbea2c6d} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'offset' to function 'overlay'. Expected: (U)Int8/16/32/64, got: String: In scope SELECT overlay('hello', 'world', 'two', 3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59406) (comment: 03205_overlay.sql) (query 6, line 6) (in query: SELECT overlay('hello', 'world', 'two', 3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c037e87 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c0312c1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c02fb7f 6. DB::(anonymous namespace)::FunctionOverlay::getReturnTypeImpl(std::vector> const&) const @ 0x00000000180bd600 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:54:02.364901 [ 24844 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'offset' to function 'overlay'. Expected: (U)Int8/16/32/64, got: String: In scope SELECT overlay('hello', 'world', 'two', 3). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c037e87 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c0312c1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c02fb7f 6. DB::(anonymous namespace)::FunctionOverlay::getReturnTypeImpl(std::vector> const&) const @ 0x00000000180bd600 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:54:02.444514 [ 2135 ] {9a451e26-c30f-4175-a5ae-0f2de97e210d} executeQuery: Code: 36. DB::Exception: index_granularity_bytes: 1 is lower than specified min_index_granularity_bytes: 1024. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59410) (comment: 01457_min_index_granularity_bytes_setting.sql) (query 2, line 3) (in query: CREATE TABLE invalid_min_index_granularity_bytes_setting (`id` UInt64, `value` String) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity_bytes = 1, min_index_granularity_bytes = 1024, index_granularity = 58156, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 75015408, compact_parts_max_bytes_to_buffer = 399099353, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 11892459, merge_max_block_size = 7553, old_parts_lifetime = 160., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 74, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 46010, primary_key_compress_block_size = 62645, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, unsigned long const&) @ 0x000000001153c70d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:538: DB::MergeTreeSettingsImpl::sanityCheck(unsigned long, bool, bool) const @ 0x0000000039ea3433 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:747: DB::MergeTreeSettings::sanityCheck(unsigned long, bool, bool) const @ 0x0000000039ea9e85 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:493: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000003975c203 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a38dc5f 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a38d037 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37f002 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:54:02.449025 [ 2135 ] {} TCPHandler: Code: 36. DB::Exception: index_granularity_bytes: 1 is lower than specified min_index_granularity_bytes: 1024. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, unsigned long const&) @ 0x000000001153c70d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:538: DB::MergeTreeSettingsImpl::sanityCheck(unsigned long, bool, bool) const @ 0x0000000039ea3433 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:747: DB::MergeTreeSettings::sanityCheck(unsigned long, bool, bool) const @ 0x0000000039ea9e85 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:493: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000003975c203 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a38dc5f 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a38d037 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37f002 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:54:02.693545 [ 24844 ] {a251fe61-2338-4ab2-a2b6-ab7b95c126b6} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 3th argument 'length' to function 'overlay'. Expected: (U)Int8/16/32/64, got: String: In scope SELECT overlay('hello', 'world', 2, 'three'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59406) (comment: 03205_overlay.sql) (query 7, line 7) (in query: SELECT overlay('hello', 'world', 2, 'three');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c037e87 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c0312c1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c02fbef 6. DB::(anonymous namespace)::FunctionOverlay::getReturnTypeImpl(std::vector> const&) const @ 0x00000000180bd600 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:54:02.698386 [ 24844 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3th argument 'length' to function 'overlay'. Expected: (U)Int8/16/32/64, got: String: In scope SELECT overlay('hello', 'world', 2, 'three'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c037e87 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c0312c1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c02fbef 6. DB::(anonymous namespace)::FunctionOverlay::getReturnTypeImpl(std::vector> const&) const @ 0x00000000180bd600 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:54:08.774388 [ 15856 ] {7e83d53f-ea68-4de0-9455-eb191d8deb62} executeQuery: Code: 80. DB::Exception: CREATE INDEX without TYPE is forbidden. SET allow_create_index_without_type=1 to ignore this statements. (INCORRECT_QUERY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50804) (comment: 02813_create_index_noop.sql) (query 2, line 2) (in query: CREATE INDEX idx_tab1_0 on tab1 (col0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/InterpreterCreateIndexQuery.cpp:53: DB::InterpreterCreateIndexQuery::execute() @ 0x00000000338e225d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 7. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:54:08.778222 [ 15856 ] {} TCPHandler: Code: 80. DB::Exception: CREATE INDEX without TYPE is forbidden. SET allow_create_index_without_type=1 to ignore this statements. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/InterpreterCreateIndexQuery.cpp:53: DB::InterpreterCreateIndexQuery::execute() @ 0x00000000338e225d 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 7. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:54:18.317285 [ 15867 ] {76071c2d-d1db-480b-9fff-ab9bafc17d2e} executeQuery: Code: 131. DB::Exception: Too large string size: 18446744073709551615. The maximum is: 17179869184.: While executing Native. (TOO_LARGE_STRING_SIZE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43536) (comment: 02683_native_too_large_size.sql) (query 1, line 1) (in query: SELECT * FROM format('Native', 'WatchID Int64, JavaEnable Int16, Title String, GoodEvent Int16, EventTime DateTime, EventDate Date, CounterID Int32, ClientIP Int32, RegionID Int32, UserID Int64, CounterClass Int16, OS Int16, UserAgent Int16, URL String, Referer String, IsRefresh Int16, RefererCategoryID Int16, RefererRegionID Int32, URLCategoryID Int16, URLRegionID Int32, ResolutionWidth Int16, ResolutionHeight Int16, ResolutionDepth Int16, FlashMajor Int16, FlashMinor Int16, FlashMinor2 String, NetMajor Int16, NetMinor Int16, UserAgentMajor Int16, UserAgentMinor String, CookieEnable Int16, JavascriptEnable Int16, IsMobile Int16, MobilePhone Int16, MobilePhoneModel String, Params String, IPNetworkID Int32, TraficSourceID Int16, SearchEngineID Int16, SearchPhrase String, AdvEngineID Int32, IsArtifical Int16, WindowClientWidth Int16, WindowClientHeight Int16, ClientTimeZone Int16, ClientEventTime DateTime, SilverlightVersion1 Int16, SilverlightVersion2 Int16, SilverlightVersion3 Int32, SilverlightVersion4 Int16, PageCharset String, CodeVersion Int32, IsLink Int16, IsDownload Int16, IsNotBounce Int16, FUniqID Int64, OriginalURL String, HID Int32, IsOldCounter Int16, IsEvent Int16, IsParameter Int16, DontCountHits Int16, WithHash Int16, HitColor String, LocalEventTime DateTime, Age Int16, Sex Int16, Income Int16, Interests Int16, Robotness Int16, RemoteIP Int32, VindowName Int32, OpenerName Int32, HistoryLength Int16, BrowserLanguage String, BrowserCountry String, SocialNetwork String, SocialAction String, HTTPError Int16, SendTiming Int32, DNSTiming Int32, ConnectTiming Int32, ResponseStartTiming Int32, ResponseEndTiming Int32, FetchTiming Int32, SocialSourceNetworkID Int16, SocialSourcePage String, ParamPrice Int64, ParamOrderID String, ParamCurrency String, ParamCurrencyID Int16, OpenstatServiceName String, OpenstatCampaignID String, OpenstatAdID String, OpenstatSourceID String, UTMSource String, UTMMedium String, UTMCampaign String, UTMContent String, UTMTerm String, FromTag String, HasGCLID Int16, RefererHash Int64, URLHash Int64, CLID Int32', $$i WatchIDInt64c*5/ !p~ úFÚÓ“2ql!è–|¨@H²Ç=ÐŒWéòˆE&Ly¹ãk=÷±pæ1þž oíC»-ÞC_ìÒŒ\Û/E‚ÜJÛ{ JavaEnableInt16TitleString GoodEventInt16 EventTimeDateTime7ðâQn$äQÃ)äQ8*äQJîâQÉ ãQµ0äQ83äQ× äQÖ1ãQ EventDateDate>>>>>>>>>> CounterIDInt32ClientIPInt32®Æz·®Æz·®Æz·®Æz·º‹I`®Æz·É^{]É^{]gU®Æz·RegionIDInt32GGGG'GÅÅåGUserIDInt64× ’•:6×Ý× ’•:6×Ý× ’•:6×Ý× ’•:6×Ýq—íJd8 ÎKs}¡ï&n%Št"6&n%Št"6ƒs—yyçóf× ’•:6×Ý CounterClassInt16OSInt16'', UserAgentInt16URLString-http://holodilInt16WindowClientWidthInt16WindowClientHeightInt16ClientTimeZoneInt16ÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿClientEventTimeDateTimeîáîáîáîáîáîáîáîáîáîáSilverlightVersion1Int16SilverlightVersion2Int16SilverlightVersion3Int32SilverlightVersion4Int16 PageCharsetString CodeVersionInt32IsLinkInt16 IsDownloadInt16 IsNotBounceInt16FUniqIDInt64%œlû©+k:¤ìWëÂm OriginalURLStringHIDInt32 IsOldCounterInt16IsEventInt16 IsParameterInt16 DontCountHitsInt16WithHashInt16HitColorString5555555555LocalEventTimeDateTime&·ãQǘãQ}žãQÝžãQ'¡ãQA¶ãQ¼£ãQ ¦ãQY’ãQ‹ÏãQAgeInt16SexInt16IncomeInt16 InterestsInt16¦: RobotnessInt16RemoteIPInt32^DIÄ^DIÄ^DIÄ^DIÄ9ê3N^DIÄ…U…U€=k^DIÄ WindowNameInt32ÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿ OpenerNameInt32ÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿ HistoryLengthInt16ÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿBrowserLanguageString����������BrowserCountryString� � � � � � � � � � SocialNetworkString SocialActionString HTTPErrorInt16 SendTimingInt32 DNSTimingInt32 ConnectTimingInt32ResponseStartTimingInt32ResponseEndTimingInt32 FetchTimingInt32SocialSourceNetworkIDInt16SocialSourcePageString ParamPriceInt64 ParamOrderIDString ParamCurrencyStringNHNHNHNHNHNHNHNHNHNHParamCurrencyIDInt16OpenstatServiceNameStringOpenstatCampaignIDString OpenstatAdIDStringOpenstatSourceIDString UTMSourceString UTMMediumString UTMCampaignString UTMContentStringUTMTermStringFromTagStringHasGCLIDInt16 RefererHashInt64X+‚Œ'ÕãûX+‚Œ'ÕãûX+‚Œ'ÕãûX+‚Œ'ÕãûX+‚Œ'ÕãûX+‚Œ'ÕãûX+‚Œ'ÕãûX+‚Œ'ÕãûX+‚Œ'ÕãûX+‚Œ'ÕãûURLHashInt64Í|3úÐb.‹Í|3úÐb.‹Í|3úÐb.‹Í|3úÐb.‹Ž oâïòeý€ à#â\X-h³ýX vÀvÍÀ‰Çh˜´9›DÍ|3úÐb.‹CLIDInt32$$);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x000000000b11932d 4. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:167: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f713ff4 5. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:258: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f70aeb2 6. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f4de523 7. ./build_docker/./src/Formats/NativeReader.cpp:97: DB::NativeReader::read() @ 0x000000003afb2698 8. ./build_docker/./src/Processors/Formats/Impl/NativeFormat.cpp:44: DB::NativeInputFormat::read() @ 0x000000003b54cc54 9. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b108bd9 10. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 11. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 15. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b0f6008 17. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000266c3409 18. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d0326ad 19. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316edd5f 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030336f50 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 2025.06.13 08:54:18.322655 [ 15867 ] {} TCPHandler: Code: 131. DB::Exception: Too large string size: 18446744073709551615. The maximum is: 17179869184.: While executing Native. (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x000000000b11932d 4. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:167: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f713ff4 5. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:258: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f70aeb2 6. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f4de523 7. ./build_docker/./src/Formats/NativeReader.cpp:97: DB::NativeReader::read() @ 0x000000003afb2698 8. ./build_docker/./src/Processors/Formats/Impl/NativeFormat.cpp:44: DB::NativeInputFormat::read() @ 0x000000003b54cc54 9. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b108bd9 10. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 11. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 15. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b0f6008 17. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000266c3409 18. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d0326ad 19. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316edd5f 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030336f50 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 2025.06.13 08:54:29.696255 [ 24864 ] {dfb68a5e-d919-491e-ac14-c69e028e0ffd} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONEachRow format file. Error: Code: 27. DB::Exception: Cannot parse input: expected '{' before: '1\n'. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02268_data.jsonl). (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49784) (comment: 02268_json_wrong_root_type_in_schema_inference.sql) (query 2, line 4) (in query: select * from file('02268_data.jsonl');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001a317bad 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:287: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003afd7729 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003afd97ae 6. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000383fa9db 7. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000383fbede 8. ./build_docker/./src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x00000000383fef51 9. ./build_docker/./src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x00000000384046c7 10. ./build_docker/./src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x0000000038406460 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x000000002660f915 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x0000000026609941 13. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002661374b 14. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d0326ad 15. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316edd5f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030336f50 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 2025.06.13 08:54:29.700667 [ 24864 ] {} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONEachRow format file. Error: Code: 27. DB::Exception: Cannot parse input: expected '{' before: '1\n'. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02268_data.jsonl). (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001a317bad 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:287: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003afd7729 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003afd97ae 6. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000383fa9db 7. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000383fbede 8. ./build_docker/./src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x00000000383fef51 9. ./build_docker/./src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x00000000384046c7 10. ./build_docker/./src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x0000000038406460 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x000000002660f915 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x0000000026609941 13. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002661374b 14. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d0326ad 15. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316edd5f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030336f50 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 2025.06.13 08:54:29.811133 [ 24864 ] {82fcb7de-0df5-4795-a5b5-8971c339c6b9} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONCompactEachRow format file. Error: Code: 27. DB::Exception: Cannot parse input: expected '[' before: '1\n'. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02268_data.jsonCompactEachRow). (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49784) (comment: 02268_json_wrong_root_type_in_schema_inference.sql) (query 4, line 7) (in query: select * from file('02268_data.jsonCompactEachRow');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001a317bad 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:287: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003afd7729 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003afd97ae 6. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000383fa9db 7. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000383fbede 8. ./build_docker/./src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x00000000383fef51 9. ./build_docker/./src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x00000000384046c7 10. ./build_docker/./src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x0000000038406460 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x000000002660f915 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x0000000026609941 13. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002661374b 14. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d0326ad 15. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316edd5f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030336f50 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 2025.06.13 08:54:29.815351 [ 24864 ] {} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONCompactEachRow format file. Error: Code: 27. DB::Exception: Cannot parse input: expected '[' before: '1\n'. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02268_data.jsonCompactEachRow). (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001a317bad 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:287: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003afd7729 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003afd97ae 6. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000383fa9db 7. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000383fbede 8. ./build_docker/./src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x00000000383fef51 9. ./build_docker/./src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x00000000384046c7 10. ./build_docker/./src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x0000000038406460 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x000000002660f915 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x0000000026609941 13. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002661374b 14. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d0326ad 15. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316edd5f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030336f50 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 2025.06.13 08:54:32.716333 [ 9253 ] {547c0810-c174-4456-ba31-476caf8320f3} executeQuery: Code: 497. DB::Exception: user2_03006_test_akx9mtyl_7385: Not enough privileges. To execute this query, it's necessary to have the grant SELECT ON *.* WITH GRANT OPTION. (Missing permissions: SELECT ON system.*, SELECT ON test_akx9mtyl.*). You can try to use the `GRANT CURRENT GRANTS(...)` statement. (ACCESS_DENIED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49840) (comment: 03006_correct_revoke_for_partial_rights.sh) (query 1, line 1) (in query: REVOKE ALL ON *.* FROM user1_03006_test_akx9mtyl_5562), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002e35f935 4. ./build_docker/./src/Access/ContextAccess.cpp:679: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(DB::AccessFlags, $T&&...)::operator()<>(DB::AccessFlags, $T&&...) const @ 0x000000002e35ce49 5. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const @ 0x000000002e35b703 6. ./build_docker/./src/Access/ContextAccess.cpp:775: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x000000002e30a0f9 7. ./build_docker/./src/Access/ContextAccess.cpp:0: DB::ContextAccess::checkGrantOption(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x000000002e2682dd 8. ./src/Access/ContextAccess.h:270: DB::InterpreterGrantQuery::execute() @ 0x0000000036e7cc84 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:54:32.722839 [ 9253 ] {} TCPHandler: Code: 497. DB::Exception: user2_03006_test_akx9mtyl_7385: Not enough privileges. To execute this query, it's necessary to have the grant SELECT ON *.* WITH GRANT OPTION. (Missing permissions: SELECT ON system.*, SELECT ON test_akx9mtyl.*). You can try to use the `GRANT CURRENT GRANTS(...)` statement. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002e35f935 4. ./build_docker/./src/Access/ContextAccess.cpp:679: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(DB::AccessFlags, $T&&...)::operator()<>(DB::AccessFlags, $T&&...) const @ 0x000000002e35ce49 5. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const @ 0x000000002e35b703 6. ./build_docker/./src/Access/ContextAccess.cpp:775: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x000000002e30a0f9 7. ./build_docker/./src/Access/ContextAccess.cpp:0: DB::ContextAccess::checkGrantOption(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x000000002e2682dd 8. ./src/Access/ContextAccess.h:270: DB::InterpreterGrantQuery::execute() @ 0x0000000036e7cc84 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:54:36.117571 [ 15871 ] {818855ff-631a-4c91-a99a-e2d331e23432} executeQuery: Code: 81. DB::Exception: Database INFORMATION_schema does not exist. Maybe you meant INFORMATION_SCHEMA?. (UNKNOWN_DATABASE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59570) (comment: 01161_information_schema.sql) (query 3, line 4) (in query: SHOW TABLES FROM INFORMATION_schema;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x0000000031a00f4a 5. ./build_docker/./src/Interpreters/InterpreterShowTablesQuery.cpp:159: DB::InterpreterShowTablesQuery::getRewrittenQuery() @ 0x0000000033845239 6. ./build_docker/./src/Interpreters/InterpreterShowTablesQuery.cpp:227: DB::InterpreterShowTablesQuery::execute() @ 0x000000003384717f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 08:54:36.121377 [ 15871 ] {} TCPHandler: Code: 81. DB::Exception: Database INFORMATION_schema does not exist. Maybe you meant INFORMATION_SCHEMA?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x0000000031a00f4a 5. ./build_docker/./src/Interpreters/InterpreterShowTablesQuery.cpp:159: DB::InterpreterShowTablesQuery::getRewrittenQuery() @ 0x0000000033845239 6. ./build_docker/./src/Interpreters/InterpreterShowTablesQuery.cpp:227: DB::InterpreterShowTablesQuery::execute() @ 0x000000003384717f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 08:54:39.328499 [ 15871 ] {73efced5-728b-4e5e-b944-ed094e3e7393} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'information_schema.taBLES' in scope SELECT count() FROM information_schema.taBLES WHERE (table_schema = currentDatabase()) AND (table_name = 't'). (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59570) (comment: 01161_information_schema.sql) (query 33, line 49) (in query: SELECT count() FROM information_schema.taBLES WHERE table_schema =currentDatabase() AND table_name = 't';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:54:39.332575 [ 15871 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'information_schema.taBLES' in scope SELECT count() FROM information_schema.taBLES WHERE (table_schema = currentDatabase()) AND (table_name = 't'). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:54:40.066761 [ 24858 ] {3df824ac-ec43-48ad-a7fa-24d86f66ea97} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 20.12 MiB (attempt to allocate chunk of 1.50 MiB bytes), maximum: 19.07 MiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59592) (comment: 01655_plan_optimizations_optimize_read_in_window_order_long.sh) (query 1, line 1) (in query: select n, sum(x) OVER (ORDER BY n, x ROWS BETWEEN 100 PRECEDING AND CURRENT ROW) from test_01655_plan_optimizations_optimize_read_in_window_order_long_n SETTINGS optimize_read_in_order=0, optimize_read_in_window_order=0, max_memory_usage=20000000, max_threads=1 format Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f53cbed 8. ./src/Common/PODArray.h:118: auto DB::ColumnVector::updatePermutation(DB::IColumn::PermutationSortDirection, DB::IColumn::PermutationSortStability, unsigned long, int, DB::PODArray, 63ul, 64ul>&, std::vector>&) const::'lambda'(auto, auto, auto)::operator()::less>(auto, auto, auto) const @ 0x0000000037dbf1a7 9. ./src/Columns/IColumnImpl.h:154: void DB::IColumn::updatePermutationImpl::less, DB::ColumnVector::equals, DB::ColumnVector::updatePermutation(DB::IColumn::PermutationSortDirection, DB::IColumn::PermutationSortStability, unsigned long, int, DB::PODArray, 63ul, 64ul>&, std::vector>&) const::'lambda'(auto, auto, auto), DB::ColumnVector::updatePermutation(DB::IColumn::PermutationSortDirection, DB::IColumn::PermutationSortStability, unsigned long, int, DB::PODArray, 63ul, 64ul>&, std::vector>&) const::'lambda'(auto, auto, auto, auto)>(unsigned long, DB::PODArray, 63ul, 64ul>&, std::vector>&, auto, auto, auto, auto) const @ 0x0000000037a88251 10. ./build_docker/./src/Columns/ColumnVector.cpp:386: DB::ColumnVector::updatePermutation(DB::IColumn::PermutationSortDirection, DB::IColumn::PermutationSortStability, unsigned long, int, DB::PODArray, 63ul, 64ul>&, std::vector>&) const @ 0x0000000037a87b18 11. ./build_docker/./src/Interpreters/sortBlock.cpp:195: DB::(anonymous namespace)::getBlockSortPermutationImpl(DB::Block const&, DB::SortDescription const&, DB::IColumn::PermutationSortStability, unsigned long, DB::PODArray, 63ul, 64ul>&) @ 0x0000000033909361 12. ./build_docker/./src/Interpreters/sortBlock.cpp:339: DB::sortBlock(DB::Block&, DB::SortDescription const&, unsigned long) @ 0x00000000339079ea 13. ./build_docker/./src/Processors/Transforms/PartialSortingTransform.cpp:137: DB::PartialSortingTransform::transform(DB::Chunk&) @ 0x000000003babcdc5 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:54:40.086979 [ 24858 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 20.12 MiB (attempt to allocate chunk of 1.50 MiB bytes), maximum: 19.07 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f53cbed 8. ./src/Common/PODArray.h:118: auto DB::ColumnVector::updatePermutation(DB::IColumn::PermutationSortDirection, DB::IColumn::PermutationSortStability, unsigned long, int, DB::PODArray, 63ul, 64ul>&, std::vector>&) const::'lambda'(auto, auto, auto)::operator()::less>(auto, auto, auto) const @ 0x0000000037dbf1a7 9. ./src/Columns/IColumnImpl.h:154: void DB::IColumn::updatePermutationImpl::less, DB::ColumnVector::equals, DB::ColumnVector::updatePermutation(DB::IColumn::PermutationSortDirection, DB::IColumn::PermutationSortStability, unsigned long, int, DB::PODArray, 63ul, 64ul>&, std::vector>&) const::'lambda'(auto, auto, auto), DB::ColumnVector::updatePermutation(DB::IColumn::PermutationSortDirection, DB::IColumn::PermutationSortStability, unsigned long, int, DB::PODArray, 63ul, 64ul>&, std::vector>&) const::'lambda'(auto, auto, auto, auto)>(unsigned long, DB::PODArray, 63ul, 64ul>&, std::vector>&, auto, auto, auto, auto) const @ 0x0000000037a88251 10. ./build_docker/./src/Columns/ColumnVector.cpp:386: DB::ColumnVector::updatePermutation(DB::IColumn::PermutationSortDirection, DB::IColumn::PermutationSortStability, unsigned long, int, DB::PODArray, 63ul, 64ul>&, std::vector>&) const @ 0x0000000037a87b18 11. ./build_docker/./src/Interpreters/sortBlock.cpp:195: DB::(anonymous namespace)::getBlockSortPermutationImpl(DB::Block const&, DB::SortDescription const&, DB::IColumn::PermutationSortStability, unsigned long, DB::PODArray, 63ul, 64ul>&) @ 0x0000000033909361 12. ./build_docker/./src/Interpreters/sortBlock.cpp:339: DB::sortBlock(DB::Block&, DB::SortDescription const&, unsigned long) @ 0x00000000339079ea 13. ./build_docker/./src/Processors/Transforms/PartialSortingTransform.cpp:137: DB::PartialSortingTransform::transform(DB::Chunk&) @ 0x000000003babcdc5 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:54:40.385843 [ 9234 ] {901e0c06-d9d9-4eb6-9727-3dde643d0c1d} executeQuery: Code: 36. DB::Exception: The 1st element of the key tuple is not of type UInt64: In scope SELECT sipHash64Keyed((0, 0), '1'). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43582) (comment: 02534_keyed_siphash.sql) (query 193, line 266) (in query: select sipHash64Keyed((0, 0), '1');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x00000000091702eb 5. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091efb0b 6. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000914c903 7. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091ef412 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 2025.06.13 08:54:40.389504 [ 9234 ] {} TCPHandler: Code: 36. DB::Exception: The 1st element of the key tuple is not of type UInt64: In scope SELECT sipHash64Keyed((0, 0), '1'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x00000000091702eb 5. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091efb0b 6. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000914c903 7. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091ef412 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 2025.06.13 08:54:40.705063 [ 9234 ] {be96b9d8-235d-4f8b-8654-01abeb31945d} executeQuery: Code: 36. DB::Exception: The 1st element of the key tuple is not of type UInt64: In scope SELECT sipHash128Keyed((0, 0), '1'). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43582) (comment: 02534_keyed_siphash.sql) (query 194, line 267) (in query: select sipHash128Keyed((0, 0), '1');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x00000000091702eb 5. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000933854a 6. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000914c903 7. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009337cd2 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 2025.06.13 08:54:40.709738 [ 9234 ] {} TCPHandler: Code: 36. DB::Exception: The 1st element of the key tuple is not of type UInt64: In scope SELECT sipHash128Keyed((0, 0), '1'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x00000000091702eb 5. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000933854a 6. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000914c903 7. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009337cd2 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 2025.06.13 08:54:40.798379 [ 24842 ] {6cb7cacb-59c4-4723-b51f-068b02c963d2} executeQuery: Code: 223. DB::Exception: [price, spend] is not an identifier. (UNEXPECTED_AST_STRUCTURE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59648) (comment: 00983_summing_merge_tree_not_an_identifier.sql) (query 1, line 1) (in query: CREATE TABLE xx (`date` Date, `id` Int64, `clicks` Int64, `price` Float64, `spend` Float64) ENGINE = SummingMergeTree([price, spend]) PARTITION BY toYYYYMM(date) ORDER BY id SAMPLE BY id SETTINGS index_granularity = 8192, min_bytes_for_wide_part = 325437081, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 116498476, compact_parts_max_bytes_to_buffer = 352620473, compact_parts_max_granules_to_buffer = 239, compact_parts_merge_max_bytes_to_prefetch_part = 31162780, merge_max_block_size = 5946, old_parts_lifetime = 335., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 20, min_merge_bytes_to_use_direct_io = 1856027964, index_granularity_bytes = 10627798, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 5, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = false, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 12667, primary_key_compress_block_size = 24235, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Parsers/ASTIdentifier.cpp:270: DB::getIdentifierName(DB::IAST const*) @ 0x000000003de81a60 5. ./src/Parsers/ASTIdentifier_fwd.h:27: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a3748c4 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:54:40.802827 [ 24842 ] {} TCPHandler: Code: 223. DB::Exception: [price, spend] is not an identifier. (UNEXPECTED_AST_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Parsers/ASTIdentifier.cpp:270: DB::getIdentifierName(DB::IAST const*) @ 0x000000003de81a60 5. ./src/Parsers/ASTIdentifier_fwd.h:27: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a3748c4 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:54:41.052644 [ 9234 ] {d8924872-5799-4b32-a7fa-2baf27badc4f} executeQuery: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash64Keyed(toUInt64(0), '1'). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43582) (comment: 02534_keyed_siphash.sql) (query 195, line 268) (in query: select sipHash64Keyed(toUInt64(0), '1');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x00000000091700be 5. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091efb0b 6. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000914c903 7. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091ef412 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 2025.06.13 08:54:41.056568 [ 9234 ] {} TCPHandler: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash64Keyed(toUInt64(0), '1'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x00000000091700be 5. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091efb0b 6. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000914c903 7. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091ef412 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 2025.06.13 08:54:41.391144 [ 9234 ] {4aca44f0-aa9e-4305-bd47-21132b12cb4d} executeQuery: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash128Keyed(toUInt64(0), '1'). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43582) (comment: 02534_keyed_siphash.sql) (query 196, line 269) (in query: select sipHash128Keyed(toUInt64(0), '1');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x00000000091700be 5. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000933854a 6. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000914c903 7. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009337cd2 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 2025.06.13 08:54:41.395260 [ 9234 ] {} TCPHandler: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash128Keyed(toUInt64(0), '1'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x00000000091700be 5. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000933854a 6. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000914c903 7. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009337cd2 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 2025.06.13 08:54:45.373536 [ 9234 ] {308ea78b-294f-4803-841f-66b5f0514a97} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(UInt16) in case if value is NULL: In scope SELECT [(255, 1048575)], sipHash128ReferenceKeyed((toUInt64(2147483646), toUInt64(9223372036854775807)), ([(NULL, 100), (NULL, NULL), (1024, 10)], toUInt64(2), toUInt64(1024)), ''), hex(sipHash128ReferenceKeyed((-9223372036854775807, 1.), '-1', NULL)), ('', toUInt64(65535), [(9223372036854775807, 9223372036854775806)], toUInt64(65536)), arrayJoin((NULL, 65537, 255), [(NULL, NULL)]) GROUP BY tupleElement((NULL, NULL, NULL, -1), toUInt64(2), 2) = NULL. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43582) (comment: 02534_keyed_siphash.sql) (query 256, line 339) (in query: SELECT [(255, 1048575)], sipHash128ReferenceKeyed((toUInt64(2147483646), toUInt64(9223372036854775807)), ([(NULL, 100), (NULL, NULL), (1024, 10)], toUInt64(2), toUInt64(1024)), ''), hex(sipHash128ReferenceKeyed((-9223372036854775807, 1.), '-1', NULL)), ('', toUInt64(65535), [(9223372036854775807, 9223372036854775806)], toUInt64(65536)), arrayJoin((NULL, 65537, 255), [(NULL, NULL)]) GROUP BY tupleElement((NULL, NULL, NULL, -1), toUInt64(2), 2) = NULL;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Columns/ColumnNullable.cpp:51: DB::ColumnNullable::getDataAt(unsigned long) const @ 0x00000000374dff8f 5. void DB::TargetSpecific::Default::FunctionAnyHash::executeGeneric(DB::impl::SipHashKeyColumns const&, DB::IColumn const*, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&) const @ 0x00000000094e93ed 6. void DB::TargetSpecific::Default::FunctionAnyHash::executeAny(DB::impl::SipHashKeyColumns const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&) const @ 0x00000000094bfaa1 7. DB::TargetSpecific::Default::FunctionAnyHash::executeForArgument(DB::impl::SipHashKeyColumns const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, bool&) const @ 0x00000000094beda4 8. DB::TargetSpecific::Default::FunctionAnyHash::executeForArgument(DB::impl::SipHashKeyColumns const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, bool&) const @ 0x00000000094bed43 9. void DB::TargetSpecific::Default::FunctionAnyHash::executeArray(DB::impl::SipHashKeyColumns const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&) const @ 0x00000000094e7aaa 10. void DB::TargetSpecific::Default::FunctionAnyHash::executeAny(DB::impl::SipHashKeyColumns const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&) const @ 0x00000000094bfafd 11. DB::TargetSpecific::Default::FunctionAnyHash::executeForArgument(DB::impl::SipHashKeyColumns const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, bool&) const @ 0x00000000094beda4 12. DB::TargetSpecific::Default::FunctionAnyHash::executeForArgument(DB::impl::SipHashKeyColumns const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, bool&) const @ 0x00000000094bed43 13. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000094be110 14. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000914c903 15. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000094bd4f2 16. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 17. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 19. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 20. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 21. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 22. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 30. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 2025.06.13 08:54:45.378045 [ 9234 ] {} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(UInt16) in case if value is NULL: In scope SELECT [(255, 1048575)], sipHash128ReferenceKeyed((toUInt64(2147483646), toUInt64(9223372036854775807)), ([(NULL, 100), (NULL, NULL), (1024, 10)], toUInt64(2), toUInt64(1024)), ''), hex(sipHash128ReferenceKeyed((-9223372036854775807, 1.), '-1', NULL)), ('', toUInt64(65535), [(9223372036854775807, 9223372036854775806)], toUInt64(65536)), arrayJoin((NULL, 65537, 255), [(NULL, NULL)]) GROUP BY tupleElement((NULL, NULL, NULL, -1), toUInt64(2), 2) = NULL. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Columns/ColumnNullable.cpp:51: DB::ColumnNullable::getDataAt(unsigned long) const @ 0x00000000374dff8f 5. void DB::TargetSpecific::Default::FunctionAnyHash::executeGeneric(DB::impl::SipHashKeyColumns const&, DB::IColumn const*, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&) const @ 0x00000000094e93ed 6. void DB::TargetSpecific::Default::FunctionAnyHash::executeAny(DB::impl::SipHashKeyColumns const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&) const @ 0x00000000094bfaa1 7. DB::TargetSpecific::Default::FunctionAnyHash::executeForArgument(DB::impl::SipHashKeyColumns const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, bool&) const @ 0x00000000094beda4 8. DB::TargetSpecific::Default::FunctionAnyHash::executeForArgument(DB::impl::SipHashKeyColumns const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, bool&) const @ 0x00000000094bed43 9. void DB::TargetSpecific::Default::FunctionAnyHash::executeArray(DB::impl::SipHashKeyColumns const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&) const @ 0x00000000094e7aaa 10. void DB::TargetSpecific::Default::FunctionAnyHash::executeAny(DB::impl::SipHashKeyColumns const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&) const @ 0x00000000094bfafd 11. DB::TargetSpecific::Default::FunctionAnyHash::executeForArgument(DB::impl::SipHashKeyColumns const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, bool&) const @ 0x00000000094beda4 12. DB::TargetSpecific::Default::FunctionAnyHash::executeForArgument(DB::impl::SipHashKeyColumns const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, bool&) const @ 0x00000000094bed43 13. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000094be110 14. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000914c903 15. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000094bd4f2 16. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 17. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 19. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 20. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 21. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 22. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 30. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 2025.06.13 08:54:46.269654 [ 24872 ] {9b90f057-1113-4c35-9759-912dedfb0813} executeQuery: Code: 407. DB::Exception: Decimal math overflow: while executing 'FUNCTION minus(materialize(_CAST('9223372036'_DateTime64(9, 'UTC'), 'DateTime64(9, 'UTC')'_String)) :: 3, _CAST('-2208988800'_DateTime64(9, 'UTC'), 'DateTime64(9, 'UTC')'_String) :: 2) -> minus(materialize(_CAST('9223372036'_DateTime64(9, 'UTC'), 'DateTime64(9, 'UTC')'_String)), _CAST('-2208988800'_DateTime64(9, 'UTC'), 'DateTime64(9, 'UTC')'_String)) Decimal(18, 9) : 1'. (DECIMAL_OVERFLOW) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60156) (comment: 02156_minus_op_with_datatime64.sql) (query 5, line 55) (in query: -- Test overflow SELECT materialize(toDateTime64('2262-04-11 23:47:16', 9, 'UTC')) - toDateTime64('1900-01-01 00:00:00', 9, 'UTC') FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. void DB::impl_::DecimalBinaryOperation, true>::processWithRightNullmapImpl<(DB::impl_::OpCase)2, void DB::impl_::DecimalBinaryOperation, true>::process<(DB::impl_::OpCase)2, true, true, DB::PODArray, 63ul, 64ul>, unsigned long>(DB::PODArray, 63ul, 64ul> const&, unsigned long const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, long, long, DB::PODArray, 63ul, 64ul> const*)::'lambda'(auto const&, auto const&), DB::PODArray, 63ul, 64ul>, unsigned long>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, unsigned long, DB::PODArray, 63ul, 64ul> const*, auto) @ 0x00000000146e1810 5. void DB::impl_::DecimalBinaryOperation, true>::process<(DB::impl_::OpCase)2, true, true, DB::PODArray, 63ul, 64ul>, unsigned long>(DB::PODArray, 63ul, 64ul> const&, unsigned long const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, long, long, DB::PODArray, 63ul, 64ul> const*) @ 0x00000000146de2fd 6. DB::FunctionBinaryArithmetic::executeDateTime64Subtraction(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014a42543 7. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014a41639 8. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014a3da4d 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 15. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 16. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 21. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:54:46.275616 [ 24872 ] {} TCPHandler: Code: 407. DB::Exception: Decimal math overflow: while executing 'FUNCTION minus(materialize(_CAST('9223372036'_DateTime64(9, 'UTC'), 'DateTime64(9, 'UTC')'_String)) :: 3, _CAST('-2208988800'_DateTime64(9, 'UTC'), 'DateTime64(9, 'UTC')'_String) :: 2) -> minus(materialize(_CAST('9223372036'_DateTime64(9, 'UTC'), 'DateTime64(9, 'UTC')'_String)), _CAST('-2208988800'_DateTime64(9, 'UTC'), 'DateTime64(9, 'UTC')'_String)) Decimal(18, 9) : 1'. (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. void DB::impl_::DecimalBinaryOperation, true>::processWithRightNullmapImpl<(DB::impl_::OpCase)2, void DB::impl_::DecimalBinaryOperation, true>::process<(DB::impl_::OpCase)2, true, true, DB::PODArray, 63ul, 64ul>, unsigned long>(DB::PODArray, 63ul, 64ul> const&, unsigned long const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, long, long, DB::PODArray, 63ul, 64ul> const*)::'lambda'(auto const&, auto const&), DB::PODArray, 63ul, 64ul>, unsigned long>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, unsigned long, DB::PODArray, 63ul, 64ul> const*, auto) @ 0x00000000146e1810 5. void DB::impl_::DecimalBinaryOperation, true>::process<(DB::impl_::OpCase)2, true, true, DB::PODArray, 63ul, 64ul>, unsigned long>(DB::PODArray, 63ul, 64ul> const&, unsigned long const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, long, long, DB::PODArray, 63ul, 64ul> const*) @ 0x00000000146de2fd 6. DB::FunctionBinaryArithmetic::executeDateTime64Subtraction(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014a42543 7. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014a41639 8. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014a3da4d 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 15. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 16. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 21. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:54:46.507144 [ 24872 ] {0fe89264-7fdb-478b-9d5f-37ecbb60b787} executeQuery: Code: 407. DB::Exception: Decimal math overflow: while executing 'FUNCTION minus(materialize(_CAST('-2208988800'_DateTime64(0, 'UTC'), 'DateTime64(0, 'UTC')'_String)) :: 3, materialize(_CAST('9223372036'_DateTime64(9, 'UTC'), 'DateTime64(9, 'UTC')'_String)) :: 1) -> minus(materialize(_CAST('-2208988800'_DateTime64(0, 'UTC'), 'DateTime64(0, 'UTC')'_String)), materialize(_CAST('9223372036'_DateTime64(9, 'UTC'), 'DateTime64(9, 'UTC')'_String))) Decimal(18, 9) : 2'. (DECIMAL_OVERFLOW) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60156) (comment: 02156_minus_op_with_datatime64.sql) (query 6, line 59) (in query: SELECT materialize(toDateTime64('1900-01-01 00:00:00', 0, 'UTC')) - materialize(toDateTime64('2262-04-11 23:47:16', 9, 'UTC'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. void DB::impl_::DecimalBinaryOperation, true>::process<(DB::impl_::OpCase)0, true, true, DB::PODArray, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, long, long, DB::PODArray, 63ul, 64ul> const*) @ 0x00000000146e2143 5. DB::FunctionBinaryArithmetic::executeDateTime64Subtraction(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014a42624 6. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014a41639 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 2025.06.13 08:54:46.513804 [ 24872 ] {} TCPHandler: Code: 407. DB::Exception: Decimal math overflow: while executing 'FUNCTION minus(materialize(_CAST('-2208988800'_DateTime64(0, 'UTC'), 'DateTime64(0, 'UTC')'_String)) :: 3, materialize(_CAST('9223372036'_DateTime64(9, 'UTC'), 'DateTime64(9, 'UTC')'_String)) :: 1) -> minus(materialize(_CAST('-2208988800'_DateTime64(0, 'UTC'), 'DateTime64(0, 'UTC')'_String)), materialize(_CAST('9223372036'_DateTime64(9, 'UTC'), 'DateTime64(9, 'UTC')'_String))) Decimal(18, 9) : 2'. (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. void DB::impl_::DecimalBinaryOperation, true>::process<(DB::impl_::OpCase)0, true, true, DB::PODArray, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, long, long, DB::PODArray, 63ul, 64ul> const*) @ 0x00000000146e2143 5. DB::FunctionBinaryArithmetic::executeDateTime64Subtraction(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014a42624 6. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014a41639 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:54:47.624666 [ 24860 ] {02c6b7b2-ad42-4b6e-b726-c00a9e6b3a63} executeQuery: Code: 36. DB::Exception: Unknown geometry type Array(Nothing): In scope SELECT polygonAreaCartesian([]). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60198) (comment: 01308_polygon_area.sql) (query 3, line 3) (in query: SELECT polygonAreaCartesian([]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionPolygonArea>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018d325c9 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 08:54:47.628758 [ 24860 ] {} TCPHandler: Code: 36. DB::Exception: Unknown geometry type Array(Nothing): In scope SELECT polygonAreaCartesian([]). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionPolygonArea>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018d325c9 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 08:54:47.816365 [ 24856 ] {b73be451-3052-4a80-9d92-423fe2982b58} executeQuery: Code: 36. DB::Exception: Primary key or secondary index contains a duplicate expression. To suppress this exception, rerun the command with setting 'allow_suspicious_indices = 1'. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60204) (comment: 02710_allow_suspicious_indices.sql) (query 2, line 4) (in query: CREATE TABLE tbl (`id` UInt32) ENGINE = MergeTree ORDER BY (id + 1, id + 1) SETTINGS index_granularity = 57810, min_bytes_for_wide_part = 364988332, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 241523788, compact_parts_max_granules_to_buffer = 193, compact_parts_merge_max_bytes_to_prefetch_part = 14500275, merge_max_block_size = 17696, old_parts_lifetime = 205., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 7060846783, index_granularity_bytes = 18191972, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 27258, primary_key_compress_block_size = 35261, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:310: DB::checkSuspiciousIndices(DB::ASTFunction const*) @ 0x000000003977ac2b 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:729: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x00000000397737d3 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:869: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000003975fc87 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:517: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000003975c601 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a38dc5f 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a38d037 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37f002 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:54:47.821086 [ 24856 ] {} TCPHandler: Code: 36. DB::Exception: Primary key or secondary index contains a duplicate expression. To suppress this exception, rerun the command with setting 'allow_suspicious_indices = 1'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:310: DB::checkSuspiciousIndices(DB::ASTFunction const*) @ 0x000000003977ac2b 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:729: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x00000000397737d3 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:869: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000003975fc87 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:517: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000003975c601 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a38dc5f 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a38d037 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37f002 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:54:48.268302 [ 24856 ] {cb96c76e-176b-4d51-8647-394846df196f} executeQuery: Code: 36. DB::Exception: Primary key or secondary index contains a duplicate expression. To suppress this exception, rerun the command with setting 'allow_suspicious_indices = 1'. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60204) (comment: 02710_allow_suspicious_indices.sql) (query 5, line 8) (in query: CREATE TABLE tbl (`id` UInt32, INDEX idx (id + 1, id + 1) TYPE minmax GRANULARITY 1) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 57810, min_bytes_for_wide_part = 364988332, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 241523788, compact_parts_max_granules_to_buffer = 193, compact_parts_merge_max_bytes_to_prefetch_part = 14500275, merge_max_block_size = 17696, old_parts_lifetime = 205., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 7060846783, index_granularity_bytes = 18191972, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 27258, primary_key_compress_block_size = 35261, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:310: DB::checkSuspiciousIndices(DB::ASTFunction const*) @ 0x000000003977ac2b 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:805: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000039776e18 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:869: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000003975fc87 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:517: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000003975c601 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a38dc5f 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a38d037 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37f002 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:54:48.273025 [ 24856 ] {} TCPHandler: Code: 36. DB::Exception: Primary key or secondary index contains a duplicate expression. To suppress this exception, rerun the command with setting 'allow_suspicious_indices = 1'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:310: DB::checkSuspiciousIndices(DB::ASTFunction const*) @ 0x000000003977ac2b 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:805: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000039776e18 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:869: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000003975fc87 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:517: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000003975c601 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a38dc5f 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a38d037 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37f002 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:54:48.756153 [ 24856 ] {9268e0d8-215e-4786-9e5a-feab49ba38a9} executeQuery: Code: 36. DB::Exception: Primary key or secondary index contains a duplicate expression. To suppress this exception, rerun the command with setting 'allow_suspicious_indices = 1'. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60204) (comment: 02710_allow_suspicious_indices.sql) (query 9, line 15) (in query: ALTER TABLE tbl ADD COLUMN `id2` UInt32, MODIFY ORDER BY (id1, id2, id2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:310: DB::checkSuspiciousIndices(DB::ASTFunction const*) @ 0x000000003977ac2b 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:729: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x00000000397737d3 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3860: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003981e60c 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:54:48.760750 [ 24856 ] {} TCPHandler: Code: 36. DB::Exception: Primary key or secondary index contains a duplicate expression. To suppress this exception, rerun the command with setting 'allow_suspicious_indices = 1'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:310: DB::checkSuspiciousIndices(DB::ASTFunction const*) @ 0x000000003977ac2b 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:729: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x00000000397737d3 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3860: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003981e60c 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:54:48.816908 [ 24856 ] {40592a9e-cec8-4260-ba96-d2add491874e} executeQuery: Code: 36. DB::Exception: Primary key or secondary index contains a duplicate expression. To suppress this exception, rerun the command with setting 'allow_suspicious_indices = 1'. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60204) (comment: 02710_allow_suspicious_indices.sql) (query 10, line 16) (in query: ALTER TABLE tbl ADD COLUMN `id2` UInt32, MODIFY ORDER BY (id1, id2, id1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:310: DB::checkSuspiciousIndices(DB::ASTFunction const*) @ 0x000000003977ac2b 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:729: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x00000000397737d3 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3860: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003981e60c 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:54:48.821622 [ 24856 ] {} TCPHandler: Code: 36. DB::Exception: Primary key or secondary index contains a duplicate expression. To suppress this exception, rerun the command with setting 'allow_suspicious_indices = 1'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:310: DB::checkSuspiciousIndices(DB::ASTFunction const*) @ 0x000000003977ac2b 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:729: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x00000000397737d3 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3860: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003981e60c 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:54:48.918643 [ 24861 ] {6527a719-056a-41cc-ba83-dab4f7a9f207} executeQuery: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 4, line 6) (in query: CREATE TABLE test (`d` Dynamic) ENGINE = MergeTree ORDER BY d SETTINGS index_granularity = 59334, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 45616054, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 25799128, merge_max_block_size = 3938, old_parts_lifetime = 43., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 49, min_merge_bytes_to_use_direct_io = 3640601313, index_granularity_bytes = 8424174, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 37461, primary_key_compress_block_size = 49576, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000003829461f 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a379e36 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:54:48.923385 [ 24861 ] {} TCPHandler: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000003829461f 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a379e36 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:54:48.959314 [ 24861 ] {49059e44-9994-44a3-b411-00ef3642e07a} executeQuery: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 5, line 7) (in query: CREATE TABLE test (`d` Dynamic) ENGINE = MergeTree ORDER BY tuple(d) SETTINGS index_granularity = 59334, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 45616054, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 25799128, merge_max_block_size = 3938, old_parts_lifetime = 43., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 49, min_merge_bytes_to_use_direct_io = 3640601313, index_granularity_bytes = 8424174, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 37461, primary_key_compress_block_size = 49576, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000003829461f 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a379e36 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:54:48.963294 [ 24861 ] {} TCPHandler: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000003829461f 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a379e36 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:54:49.215249 [ 24861 ] {56bff9db-0074-4404-9e24-930dcc05e6cb} executeQuery: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 6, line 8) (in query: CREATE TABLE test (`d` Dynamic) ENGINE = MergeTree ORDER BY [d] SETTINGS index_granularity = 59334, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 45616054, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 25799128, merge_max_block_size = 3938, old_parts_lifetime = 43., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 49, min_merge_bytes_to_use_direct_io = 3640601313, index_granularity_bytes = 8424174, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 37461, primary_key_compress_block_size = 49576, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&)::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x0000000038299363 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f25b382 6. ./build_docker/./src/Storages/KeyDescription.cpp:188: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000382941fb 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a379e36 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 2025.06.13 08:54:49.219973 [ 24861 ] {} TCPHandler: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&)::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x0000000038299363 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f25b382 6. ./build_docker/./src/Storages/KeyDescription.cpp:188: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000382941fb 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a379e36 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 2025.06.13 08:54:49.308943 [ 24856 ] {da796732-16ea-4fa8-ae72-762482427f6b} executeQuery: Code: 36. DB::Exception: Primary key or secondary index contains a duplicate expression. To suppress this exception, rerun the command with setting 'allow_suspicious_indices = 1'. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60204) (comment: 02710_allow_suspicious_indices.sql) (query 14, line 21) (in query: ALTER TABLE tbl ADD INDEX idx (id+1, id, id+1) TYPE minmax;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:310: DB::checkSuspiciousIndices(DB::ASTFunction const*) @ 0x000000003977ac2b 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:805: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000039776e18 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3860: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003981e60c 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:54:49.313361 [ 24856 ] {} TCPHandler: Code: 36. DB::Exception: Primary key or secondary index contains a duplicate expression. To suppress this exception, rerun the command with setting 'allow_suspicious_indices = 1'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:310: DB::checkSuspiciousIndices(DB::ASTFunction const*) @ 0x000000003977ac2b 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:805: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000039776e18 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3860: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003981e60c 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:54:49.445480 [ 24861 ] {eb9278de-7d57-4d86-b733-527a7b423976} executeQuery: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 7, line 9) (in query: CREATE TABLE test (`d` Dynamic) ENGINE = MergeTree ORDER BY map('str', d) SETTINGS index_granularity = 59334, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 45616054, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 25799128, merge_max_block_size = 3938, old_parts_lifetime = 43., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 49, min_merge_bytes_to_use_direct_io = 3640601313, index_granularity_bytes = 8424174, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 37461, primary_key_compress_block_size = 49576, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&)::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x0000000038299363 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f2c55b5 6. ./build_docker/./src/Storages/KeyDescription.cpp:188: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000382941fb 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a379e36 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 2025.06.13 08:54:49.450117 [ 24861 ] {} TCPHandler: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&)::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x0000000038299363 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f2c55b5 6. ./build_docker/./src/Storages/KeyDescription.cpp:188: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000382941fb 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a379e36 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 2025.06.13 08:54:49.661338 [ 24861 ] {7a79f54c-da11-49cb-b283-948e09471995} executeQuery: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 8, line 10) (in query: CREATE TABLE test (`d` Dynamic) ENGINE = MergeTree PRIMARY KEY d ORDER BY tuple() SETTINGS index_granularity = 59334, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 45616054, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 25799128, merge_max_block_size = 3938, old_parts_lifetime = 43., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 49, min_merge_bytes_to_use_direct_io = 3640601313, index_granularity_bytes = 8424174, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 37461, primary_key_compress_block_size = 49576, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000003829461f 5. ./build_docker/./src/Storages/KeyDescription.cpp:93: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003829633f 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:676: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37a258 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:54:49.665905 [ 24861 ] {} TCPHandler: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000003829461f 5. ./build_docker/./src/Storages/KeyDescription.cpp:93: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003829633f 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:676: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37a258 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:54:49.875014 [ 24861 ] {ffe14f10-c79e-43ec-85ca-a8f144bce01f} executeQuery: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 9, line 11) (in query: CREATE TABLE test (`d` Dynamic) ENGINE = MergeTree PARTITION BY d ORDER BY tuple() SETTINGS index_granularity = 59334, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 45616054, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 25799128, merge_max_block_size = 3938, old_parts_lifetime = 43., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 49, min_merge_bytes_to_use_direct_io = 3640601313, index_granularity_bytes = 8424174, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 37461, primary_key_compress_block_size = 49576, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000003829461f 5. ./build_docker/./src/Storages/KeyDescription.cpp:93: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003829633f 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:641: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37736f 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:54:49.879400 [ 24861 ] {} TCPHandler: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000003829461f 5. ./build_docker/./src/Storages/KeyDescription.cpp:93: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003829633f 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:641: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37736f 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:54:49.917420 [ 24861 ] {565ab2d0-e9d9-4a33-a11b-3ecbd9ddb304} executeQuery: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 10, line 12) (in query: CREATE TABLE test (`d` Dynamic) ENGINE = MergeTree PARTITION BY tuple(d) ORDER BY tuple() SETTINGS index_granularity = 59334, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 45616054, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 25799128, merge_max_block_size = 3938, old_parts_lifetime = 43., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 49, min_merge_bytes_to_use_direct_io = 3640601313, index_granularity_bytes = 8424174, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 37461, primary_key_compress_block_size = 49576, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000003829461f 5. ./build_docker/./src/Storages/KeyDescription.cpp:93: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003829633f 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:641: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37736f 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:54:49.921867 [ 24861 ] {} TCPHandler: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000003829461f 5. ./build_docker/./src/Storages/KeyDescription.cpp:93: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003829633f 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:641: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37736f 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:54:50.159124 [ 24861 ] {07157fe0-2534-4ad5-859e-2a00530f87ae} executeQuery: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 11, line 13) (in query: CREATE TABLE test (`d` Dynamic) ENGINE = MergeTree PARTITION BY [d] ORDER BY tuple() SETTINGS index_granularity = 59334, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 45616054, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 25799128, merge_max_block_size = 3938, old_parts_lifetime = 43., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 49, min_merge_bytes_to_use_direct_io = 3640601313, index_granularity_bytes = 8424174, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 37461, primary_key_compress_block_size = 49576, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&)::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x0000000038299363 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f25b382 6. ./build_docker/./src/Storages/KeyDescription.cpp:188: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000382941fb 7. ./build_docker/./src/Storages/KeyDescription.cpp:93: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003829633f 8. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:641: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37736f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:54:50.163424 [ 24861 ] {} TCPHandler: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&)::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x0000000038299363 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f25b382 6. ./build_docker/./src/Storages/KeyDescription.cpp:188: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000382941fb 7. ./build_docker/./src/Storages/KeyDescription.cpp:93: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003829633f 8. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:641: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37736f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:54:50.388489 [ 24861 ] {71c2deee-6535-4750-9c40-5293069942b1} executeQuery: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 12, line 14) (in query: CREATE TABLE test (`d` Dynamic) ENGINE = MergeTree PARTITION BY map('str', d) ORDER BY tuple() SETTINGS index_granularity = 59334, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 45616054, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 25799128, merge_max_block_size = 3938, old_parts_lifetime = 43., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 49, min_merge_bytes_to_use_direct_io = 3640601313, index_granularity_bytes = 8424174, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 37461, primary_key_compress_block_size = 49576, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&)::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x0000000038299363 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f2c55b5 6. ./build_docker/./src/Storages/KeyDescription.cpp:188: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000382941fb 7. ./build_docker/./src/Storages/KeyDescription.cpp:93: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003829633f 8. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:641: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37736f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:54:50.393535 [ 24861 ] {} TCPHandler: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&)::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x0000000038299363 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f2c55b5 6. ./build_docker/./src/Storages/KeyDescription.cpp:188: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000382941fb 7. ./build_docker/./src/Storages/KeyDescription.cpp:93: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003829633f 8. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:641: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37736f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:54:50.435201 [ 24861 ] {d5370ebb-c704-4836-9c65-dc787ed5e574} executeQuery: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 13, line 16) (in query: CREATE TABLE test (`d` Variant(UInt64)) ENGINE = MergeTree ORDER BY d SETTINGS index_granularity = 59334, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 45616054, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 25799128, merge_max_block_size = 3938, old_parts_lifetime = 43., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 49, min_merge_bytes_to_use_direct_io = 3640601313, index_granularity_bytes = 8424174, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 37461, primary_key_compress_block_size = 49576, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000003829461f 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a379e36 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:54:50.440200 [ 24861 ] {} TCPHandler: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000003829461f 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a379e36 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:54:50.476431 [ 24861 ] {2044d248-ba0f-4f6f-ad46-b2447243c3e0} executeQuery: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 14, line 17) (in query: CREATE TABLE test (`d` Variant(UInt64)) ENGINE = MergeTree ORDER BY tuple(d) SETTINGS index_granularity = 59334, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 45616054, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 25799128, merge_max_block_size = 3938, old_parts_lifetime = 43., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 49, min_merge_bytes_to_use_direct_io = 3640601313, index_granularity_bytes = 8424174, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 37461, primary_key_compress_block_size = 49576, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000003829461f 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a379e36 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:54:50.480752 [ 24861 ] {} TCPHandler: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000003829461f 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a379e36 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:54:50.516848 [ 24861 ] {50cb3f0a-1468-476f-8cf0-6c0cd35899b9} executeQuery: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 15, line 18) (in query: CREATE TABLE test (`d` Variant(UInt64)) ENGINE = MergeTree ORDER BY [d] SETTINGS index_granularity = 59334, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 45616054, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 25799128, merge_max_block_size = 3938, old_parts_lifetime = 43., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 49, min_merge_bytes_to_use_direct_io = 3640601313, index_granularity_bytes = 8424174, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 37461, primary_key_compress_block_size = 49576, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&)::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x0000000038299363 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f25b382 6. ./build_docker/./src/Storages/KeyDescription.cpp:188: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000382941fb 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a379e36 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 2025.06.13 08:54:50.521576 [ 24861 ] {} TCPHandler: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&)::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x0000000038299363 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f25b382 6. ./build_docker/./src/Storages/KeyDescription.cpp:188: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000382941fb 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a379e36 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 2025.06.13 08:54:50.579768 [ 24861 ] {d604353b-a01b-46a6-93c5-e8da8de735dc} executeQuery: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 16, line 19) (in query: CREATE TABLE test (`d` Variant(UInt64)) ENGINE = MergeTree ORDER BY map('str', d) SETTINGS index_granularity = 59334, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 45616054, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 25799128, merge_max_block_size = 3938, old_parts_lifetime = 43., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 49, min_merge_bytes_to_use_direct_io = 3640601313, index_granularity_bytes = 8424174, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 37461, primary_key_compress_block_size = 49576, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&)::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x0000000038299363 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f2c55b5 6. ./build_docker/./src/Storages/KeyDescription.cpp:188: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000382941fb 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a379e36 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 2025.06.13 08:54:50.585699 [ 24861 ] {} TCPHandler: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&)::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x0000000038299363 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f2c55b5 6. ./build_docker/./src/Storages/KeyDescription.cpp:188: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000382941fb 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a379e36 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 2025.06.13 08:54:50.639988 [ 24861 ] {d341d6e3-5c6f-4bfd-a0ae-b038949542a6} executeQuery: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 17, line 20) (in query: CREATE TABLE test (`d` Variant(UInt64)) ENGINE = MergeTree PRIMARY KEY d ORDER BY tuple() SETTINGS index_granularity = 59334, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 45616054, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 25799128, merge_max_block_size = 3938, old_parts_lifetime = 43., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 49, min_merge_bytes_to_use_direct_io = 3640601313, index_granularity_bytes = 8424174, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 37461, primary_key_compress_block_size = 49576, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000003829461f 5. ./build_docker/./src/Storages/KeyDescription.cpp:93: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003829633f 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:676: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37a258 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:54:50.645036 [ 24861 ] {} TCPHandler: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000003829461f 5. ./build_docker/./src/Storages/KeyDescription.cpp:93: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003829633f 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:676: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37a258 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:54:50.690453 [ 24861 ] {4a149871-fa49-4282-b347-beec27511f8a} executeQuery: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 18, line 21) (in query: CREATE TABLE test (`d` Variant(UInt64)) ENGINE = MergeTree PARTITION BY d ORDER BY tuple() SETTINGS index_granularity = 59334, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 45616054, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 25799128, merge_max_block_size = 3938, old_parts_lifetime = 43., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 49, min_merge_bytes_to_use_direct_io = 3640601313, index_granularity_bytes = 8424174, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 37461, primary_key_compress_block_size = 49576, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000003829461f 5. ./build_docker/./src/Storages/KeyDescription.cpp:93: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003829633f 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:641: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37736f 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:54:50.694587 [ 24861 ] {} TCPHandler: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000003829461f 5. ./build_docker/./src/Storages/KeyDescription.cpp:93: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003829633f 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:641: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37736f 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:54:50.732808 [ 24861 ] {2f683616-c226-48a2-89fa-57e0056fa197} executeQuery: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 19, line 22) (in query: CREATE TABLE test (`d` Variant(UInt64)) ENGINE = MergeTree PARTITION BY tuple(d) ORDER BY tuple() SETTINGS index_granularity = 59334, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 45616054, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 25799128, merge_max_block_size = 3938, old_parts_lifetime = 43., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 49, min_merge_bytes_to_use_direct_io = 3640601313, index_granularity_bytes = 8424174, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 37461, primary_key_compress_block_size = 49576, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000003829461f 5. ./build_docker/./src/Storages/KeyDescription.cpp:93: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003829633f 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:641: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37736f 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:54:50.736981 [ 24861 ] {} TCPHandler: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000003829461f 5. ./build_docker/./src/Storages/KeyDescription.cpp:93: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003829633f 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:641: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37736f 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:54:50.777626 [ 24861 ] {978395c1-810a-448a-becb-19ab686066ae} executeQuery: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 20, line 23) (in query: CREATE TABLE test (`d` Variant(UInt64)) ENGINE = MergeTree PARTITION BY [d] ORDER BY tuple() SETTINGS index_granularity = 59334, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 45616054, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 25799128, merge_max_block_size = 3938, old_parts_lifetime = 43., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 49, min_merge_bytes_to_use_direct_io = 3640601313, index_granularity_bytes = 8424174, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 37461, primary_key_compress_block_size = 49576, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&)::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x0000000038299363 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f25b382 6. ./build_docker/./src/Storages/KeyDescription.cpp:188: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000382941fb 7. ./build_docker/./src/Storages/KeyDescription.cpp:93: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003829633f 8. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:641: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37736f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:54:50.781770 [ 24861 ] {} TCPHandler: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&)::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x0000000038299363 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f25b382 6. ./build_docker/./src/Storages/KeyDescription.cpp:188: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000382941fb 7. ./build_docker/./src/Storages/KeyDescription.cpp:93: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003829633f 8. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:641: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37736f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:54:50.823737 [ 24861 ] {1b07e6f0-65bd-4eb6-8647-269ff61261f0} executeQuery: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 21, line 24) (in query: CREATE TABLE test (`d` Variant(UInt64)) ENGINE = MergeTree PARTITION BY map('str', d) ORDER BY tuple() SETTINGS index_granularity = 59334, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 45616054, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 25799128, merge_max_block_size = 3938, old_parts_lifetime = 43., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 49, min_merge_bytes_to_use_direct_io = 3640601313, index_granularity_bytes = 8424174, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 37461, primary_key_compress_block_size = 49576, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&)::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x0000000038299363 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f2c55b5 6. ./build_docker/./src/Storages/KeyDescription.cpp:188: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000382941fb 7. ./build_docker/./src/Storages/KeyDescription.cpp:93: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003829633f 8. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:641: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37736f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:54:50.827992 [ 24861 ] {} TCPHandler: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&)::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x0000000038299363 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f2c55b5 6. ./build_docker/./src/Storages/KeyDescription.cpp:188: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000382941fb 7. ./build_docker/./src/Storages/KeyDescription.cpp:93: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003829633f 8. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:641: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37736f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:54:51.144883 [ 15838 ] {92934792-0dbf-4b5c-a54b-f6a109de9fb3} executeQuery: Code: 36. DB::Exception: 'lifetime' parameter is redundant for the dictionary' of layout 'direct': While processing PRIMARY KEY key SOURCE(CLICKHOUSE(TABLE 'dict_source')) LIFETIME(MIN 0 MAX 0) LAYOUT(DIRECT()). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60320) (comment: 02716_create_direct_dict_with_lifetime_throws.sql) (query 2, line 3) (in query: CREATE DICTIONARY dict(`key` UInt64,`value` String) PRIMARY KEY key SOURCE(CLICKHOUSE(table 'dict_source')) LAYOUT(DIRECT()) LIFETIME(0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Dictionaries/getDictionaryConfigurationFromAST.cpp:598: DB::checkLifetime(DB::ASTCreateQuery const&) @ 0x000000002f7bf005 5. ./build_docker/./src/Dictionaries/getDictionaryConfigurationFromAST.cpp:610: DB::getDictionaryConfigurationFromAST(DB::ASTCreateQuery const&, std::shared_ptr, String const&) @ 0x000000002f7bf7e1 6. ./build_docker/./src/Databases/DDLDependencyVisitor.cpp:128: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000002f7ad892 7. ./src/Interpreters/InDepthNodeVisitor.h:61: void DB::InDepthNodeVisitor const>::visitImpl(std::shared_ptr const&) @ 0x000000002f7ac23d 8. ./src/Interpreters/InDepthNodeVisitor.h:92: DB::InDepthNodeVisitor const>::visit(std::shared_ptr const&) @ 0x000000002f7aa0f9 9. ./build_docker/./src/Databases/DDLDependencyVisitor.cpp:501: DB::getDependenciesFromCreateQuery(std::shared_ptr const&, DB::QualifiedTableName const&, std::shared_ptr const&, String const&, bool) @ 0x000000002f7a9452 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1491: DB::(anonymous namespace)::checkTableCanBeAddedWithNoCyclicDependencies(DB::ASTCreateQuery const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000329269d0 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1911: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291a252 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:54:51.149336 [ 15838 ] {} TCPHandler: Code: 36. DB::Exception: 'lifetime' parameter is redundant for the dictionary' of layout 'direct': While processing PRIMARY KEY key SOURCE(CLICKHOUSE(TABLE 'dict_source')) LIFETIME(MIN 0 MAX 0) LAYOUT(DIRECT()). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Dictionaries/getDictionaryConfigurationFromAST.cpp:598: DB::checkLifetime(DB::ASTCreateQuery const&) @ 0x000000002f7bf005 5. ./build_docker/./src/Dictionaries/getDictionaryConfigurationFromAST.cpp:610: DB::getDictionaryConfigurationFromAST(DB::ASTCreateQuery const&, std::shared_ptr, String const&) @ 0x000000002f7bf7e1 6. ./build_docker/./src/Databases/DDLDependencyVisitor.cpp:128: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000002f7ad892 7. ./src/Interpreters/InDepthNodeVisitor.h:61: void DB::InDepthNodeVisitor const>::visitImpl(std::shared_ptr const&) @ 0x000000002f7ac23d 8. ./src/Interpreters/InDepthNodeVisitor.h:92: DB::InDepthNodeVisitor const>::visit(std::shared_ptr const&) @ 0x000000002f7aa0f9 9. ./build_docker/./src/Databases/DDLDependencyVisitor.cpp:501: DB::getDependenciesFromCreateQuery(std::shared_ptr const&, DB::QualifiedTableName const&, std::shared_ptr const&, String const&, bool) @ 0x000000002f7a9452 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1491: DB::(anonymous namespace)::checkTableCanBeAddedWithNoCyclicDependencies(DB::ASTCreateQuery const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000329269d0 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1911: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291a252 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:54:51.359705 [ 24861 ] {81ecc8e0-a3cb-40bc-80ac-9975b5dc21fe} executeQuery: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in ORDER BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_order_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 27, line 34) (in query: select * from test order by d;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4159: DB::QueryAnalyzer::validateSortingKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const::$_0::operator()(DB::IDataType const&) const @ 0x00000000303bc85c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4170: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303b5034 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5641: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030e0c7 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:54:51.364070 [ 24861 ] {} TCPHandler: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in ORDER BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_order_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4159: DB::QueryAnalyzer::validateSortingKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const::$_0::operator()(DB::IDataType const&) const @ 0x00000000303bc85c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4170: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303b5034 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5641: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030e0c7 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:54:51.660512 [ 24861 ] {69cff82a-c819-43cd-959f-215cc2aabd36} executeQuery: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in ORDER BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_order_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 28, line 35) (in query: select * from test order by tuple(d);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4159: DB::QueryAnalyzer::validateSortingKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const::$_0::operator()(DB::IDataType const&) const @ 0x00000000303bc85c 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::IdentifierResolveScope const&) const::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x00000000303d6689 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f31ef10 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4171: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303b50f6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5641: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030e0c7 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:54:51.665938 [ 24861 ] {} TCPHandler: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in ORDER BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_order_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4159: DB::QueryAnalyzer::validateSortingKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const::$_0::operator()(DB::IDataType const&) const @ 0x00000000303bc85c 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::IdentifierResolveScope const&) const::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x00000000303d6689 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f31ef10 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4171: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303b50f6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5641: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030e0c7 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:54:51.889218 [ 24861 ] {f0ff98f4-bf2e-4787-924d-6fa477e08fa7} executeQuery: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in ORDER BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_order_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 29, line 36) (in query: select * from test order by array(d);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4159: DB::QueryAnalyzer::validateSortingKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const::$_0::operator()(DB::IDataType const&) const @ 0x00000000303bc85c 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::IdentifierResolveScope const&) const::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x00000000303d6689 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f25b382 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4171: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303b50f6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5641: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030e0c7 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:54:51.894610 [ 24861 ] {} TCPHandler: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in ORDER BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_order_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4159: DB::QueryAnalyzer::validateSortingKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const::$_0::operator()(DB::IDataType const&) const @ 0x00000000303bc85c 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::IdentifierResolveScope const&) const::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x00000000303d6689 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f25b382 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4171: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303b50f6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5641: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030e0c7 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:54:51.991327 [ 24843 ] {af988d4d-faa3-4768-b949-c970900078e1} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 20.12 MiB (attempt to allocate chunk of 1.50 MiB bytes), maximum: 19.07 MiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60366) (comment: 01655_plan_optimizations_optimize_read_in_window_order_long.sh) (query 1, line 1) (in query: select n, sum(x) OVER (ORDER BY n, x ROWS BETWEEN 100 PRECEDING AND CURRENT ROW) from test_01655_plan_optimizations_optimize_read_in_window_order_long_n_x SETTINGS optimize_read_in_order=0, optimize_read_in_window_order=0, max_memory_usage=20000000, max_threads=1 format Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f53cbed 8. ./src/Common/PODArray.h:118: auto DB::ColumnVector::updatePermutation(DB::IColumn::PermutationSortDirection, DB::IColumn::PermutationSortStability, unsigned long, int, DB::PODArray, 63ul, 64ul>&, std::vector>&) const::'lambda'(auto, auto, auto)::operator()::less>(auto, auto, auto) const @ 0x0000000037dbf1a7 9. ./src/Columns/IColumnImpl.h:154: void DB::IColumn::updatePermutationImpl::less, DB::ColumnVector::equals, DB::ColumnVector::updatePermutation(DB::IColumn::PermutationSortDirection, DB::IColumn::PermutationSortStability, unsigned long, int, DB::PODArray, 63ul, 64ul>&, std::vector>&) const::'lambda'(auto, auto, auto), DB::ColumnVector::updatePermutation(DB::IColumn::PermutationSortDirection, DB::IColumn::PermutationSortStability, unsigned long, int, DB::PODArray, 63ul, 64ul>&, std::vector>&) const::'lambda'(auto, auto, auto, auto)>(unsigned long, DB::PODArray, 63ul, 64ul>&, std::vector>&, auto, auto, auto, auto) const @ 0x0000000037a88251 10. ./build_docker/./src/Columns/ColumnVector.cpp:386: DB::ColumnVector::updatePermutation(DB::IColumn::PermutationSortDirection, DB::IColumn::PermutationSortStability, unsigned long, int, DB::PODArray, 63ul, 64ul>&, std::vector>&) const @ 0x0000000037a87b18 11. ./build_docker/./src/Interpreters/sortBlock.cpp:195: DB::(anonymous namespace)::getBlockSortPermutationImpl(DB::Block const&, DB::SortDescription const&, DB::IColumn::PermutationSortStability, unsigned long, DB::PODArray, 63ul, 64ul>&) @ 0x0000000033909361 12. ./build_docker/./src/Interpreters/sortBlock.cpp:339: DB::sortBlock(DB::Block&, DB::SortDescription const&, unsigned long) @ 0x00000000339079ea 13. ./build_docker/./src/Processors/Transforms/PartialSortingTransform.cpp:137: DB::PartialSortingTransform::transform(DB::Chunk&) @ 0x000000003babcdc5 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:54:52.054987 [ 24843 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 20.12 MiB (attempt to allocate chunk of 1.50 MiB bytes), maximum: 19.07 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f53cbed 8. ./src/Common/PODArray.h:118: auto DB::ColumnVector::updatePermutation(DB::IColumn::PermutationSortDirection, DB::IColumn::PermutationSortStability, unsigned long, int, DB::PODArray, 63ul, 64ul>&, std::vector>&) const::'lambda'(auto, auto, auto)::operator()::less>(auto, auto, auto) const @ 0x0000000037dbf1a7 9. ./src/Columns/IColumnImpl.h:154: void DB::IColumn::updatePermutationImpl::less, DB::ColumnVector::equals, DB::ColumnVector::updatePermutation(DB::IColumn::PermutationSortDirection, DB::IColumn::PermutationSortStability, unsigned long, int, DB::PODArray, 63ul, 64ul>&, std::vector>&) const::'lambda'(auto, auto, auto), DB::ColumnVector::updatePermutation(DB::IColumn::PermutationSortDirection, DB::IColumn::PermutationSortStability, unsigned long, int, DB::PODArray, 63ul, 64ul>&, std::vector>&) const::'lambda'(auto, auto, auto, auto)>(unsigned long, DB::PODArray, 63ul, 64ul>&, std::vector>&, auto, auto, auto, auto) const @ 0x0000000037a88251 10. ./build_docker/./src/Columns/ColumnVector.cpp:386: DB::ColumnVector::updatePermutation(DB::IColumn::PermutationSortDirection, DB::IColumn::PermutationSortStability, unsigned long, int, DB::PODArray, 63ul, 64ul>&, std::vector>&) const @ 0x0000000037a87b18 11. ./build_docker/./src/Interpreters/sortBlock.cpp:195: DB::(anonymous namespace)::getBlockSortPermutationImpl(DB::Block const&, DB::SortDescription const&, DB::IColumn::PermutationSortStability, unsigned long, DB::PODArray, 63ul, 64ul>&) @ 0x0000000033909361 12. ./build_docker/./src/Interpreters/sortBlock.cpp:339: DB::sortBlock(DB::Block&, DB::SortDescription const&, unsigned long) @ 0x00000000339079ea 13. ./build_docker/./src/Processors/Transforms/PartialSortingTransform.cpp:137: DB::PartialSortingTransform::transform(DB::Chunk&) @ 0x000000003babcdc5 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:54:52.191206 [ 24861 ] {80220e27-99f2-494c-8f18-734d02e5b80d} executeQuery: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in ORDER BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_order_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 30, line 37) (in query: select * from test order by map('str', d);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4159: DB::QueryAnalyzer::validateSortingKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const::$_0::operator()(DB::IDataType const&) const @ 0x00000000303bc85c 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::IdentifierResolveScope const&) const::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x00000000303d6689 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f2c55b5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4171: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303b50f6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5641: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030e0c7 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:54:52.196059 [ 24861 ] {} TCPHandler: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in ORDER BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_order_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4159: DB::QueryAnalyzer::validateSortingKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const::$_0::operator()(DB::IDataType const&) const @ 0x00000000303bc85c 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::IdentifierResolveScope const&) const::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x00000000303d6689 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f2c55b5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4171: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303b50f6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5641: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030e0c7 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:54:52.451632 [ 24861 ] {74c29231-9c60-4a38-816c-5f88193f62c9} executeQuery: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 33, line 42) (in query: select * from test group by d;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4253: DB::QueryAnalyzer::validateGroupByKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const @ 0x00000000303c05ca 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4236: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x00000000303be141 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5618: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030d524 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:54:52.455882 [ 24861 ] {} TCPHandler: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4253: DB::QueryAnalyzer::validateGroupByKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const @ 0x00000000303c05ca 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4236: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x00000000303be141 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5618: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030d524 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:54:52.487601 [ 24861 ] {9b86b469-f2c8-4d66-ad9e-87636b2e433c} executeQuery: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 34, line 43) (in query: select * from test group by tuple(d);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4253: DB::QueryAnalyzer::validateGroupByKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const @ 0x00000000303c05ca 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4236: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x00000000303be141 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5618: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030d524 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:54:52.492887 [ 24861 ] {} TCPHandler: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4253: DB::QueryAnalyzer::validateGroupByKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const @ 0x00000000303c05ca 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4236: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x00000000303be141 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5618: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030d524 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:54:52.759467 [ 24861 ] {7fc4fb39-e241-4343-b873-56578b505d44} executeQuery: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 35, line 44) (in query: select array(d) from test group by array(d);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4253: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::IdentifierResolveScope const&) const::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x00000000303d6823 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f25b382 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4262: DB::QueryAnalyzer::validateGroupByKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const @ 0x00000000303c044f 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4236: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x00000000303be141 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5618: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030d524 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:54:52.764565 [ 24861 ] {} TCPHandler: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4253: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::IdentifierResolveScope const&) const::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x00000000303d6823 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f25b382 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4262: DB::QueryAnalyzer::validateGroupByKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const @ 0x00000000303c044f 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4236: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x00000000303be141 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5618: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030d524 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:54:53.023468 [ 24861 ] {dc185b42-7aa1-430a-bb07-44246d4d7475} executeQuery: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 36, line 45) (in query: select map('str', d) from test group by map('str', d);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4253: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::IdentifierResolveScope const&) const::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x00000000303d6823 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f2c55b5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4262: DB::QueryAnalyzer::validateGroupByKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const @ 0x00000000303c044f 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4236: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x00000000303be141 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5618: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030d524 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:54:53.028172 [ 24861 ] {} TCPHandler: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4253: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::IdentifierResolveScope const&) const::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x00000000303d6823 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f2c55b5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4262: DB::QueryAnalyzer::validateGroupByKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const @ 0x00000000303c044f 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4236: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x00000000303be141 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5618: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030d524 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:54:53.230712 [ 24861 ] {6775a5d7-4774-45cf-a4ed-05bbe3793540} executeQuery: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 37, line 46) (in query: select * from test group by grouping sets ((d), ('str'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4253: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x00000000303be728 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5618: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030d524 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:54:53.235895 [ 24861 ] {} TCPHandler: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4253: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x00000000303be728 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5618: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030d524 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:54:54.425405 [ 15837 ] {cda30b81-da61-4da5-bb3d-e6fe36b378b0} executeQuery: Code: 80. DB::Exception: Failed to rewrite ', ...' to INNER JOIN: no equi-join conditions found in WHERE clause. You may set setting `cross_to_inner_join_rewrite` to `1` to allow slow CROSS JOIN for this case. (INCORRECT_QUERY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38666) (comment: 02364_setting_cross_to_inner_rewrite.sql) (query 13, line 17) (in query: SELECT count() = 1 FROM t1, t2 WHERE t1.x > t2.x;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Analyzer/Passes/CrossToInnerJoinPass.cpp:355: DB::(anonymous namespace)::CrossToInnerJoinVisitor::checkNotRewritten(bool, std::shared_ptr const&) @ 0x000000003100ce0e 5. ./build_docker/./src/Analyzer/Passes/CrossToInnerJoinPass.cpp:366: DB::InDepthQueryTreeVisitorWithContext::visit(std::shared_ptr&) @ 0x0000000031004797 6. ./build_docker/./src/Analyzer/Passes/CrossToInnerJoinPass.cpp:392: DB::CrossToInnerJoinPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030ffcfbf 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 2025.06.13 08:54:54.429736 [ 15837 ] {} TCPHandler: Code: 80. DB::Exception: Failed to rewrite ', ...' to INNER JOIN: no equi-join conditions found in WHERE clause. You may set setting `cross_to_inner_join_rewrite` to `1` to allow slow CROSS JOIN for this case. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Analyzer/Passes/CrossToInnerJoinPass.cpp:355: DB::(anonymous namespace)::CrossToInnerJoinVisitor::checkNotRewritten(bool, std::shared_ptr const&) @ 0x000000003100ce0e 5. ./build_docker/./src/Analyzer/Passes/CrossToInnerJoinPass.cpp:366: DB::InDepthQueryTreeVisitorWithContext::visit(std::shared_ptr&) @ 0x0000000031004797 6. ./build_docker/./src/Analyzer/Passes/CrossToInnerJoinPass.cpp:392: DB::CrossToInnerJoinPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030ffcfbf 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 2025.06.13 08:54:54.519752 [ 24861 ] {ff8c4d3b-c250-4cae-a18f-fa8fff5108e1} executeQuery: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in ORDER BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_order_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 52, line 67) (in query: select * from test order by d;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1718: DB::SelectQueryExpressionAnalyzer::validateOrderByKeyType(std::shared_ptr const&) const::$_0::operator()(DB::IDataType const&) const @ 0x0000000031b0ac76 5. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1729: DB::SelectQueryExpressionAnalyzer::appendOrderBy(DB::ExpressionActionsChain&, bool, bool, std::vector, std::allocator>>&) @ 0x0000000031b071e2 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2257: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b1cbbc 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 12. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:54:54.524840 [ 24861 ] {} TCPHandler: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in ORDER BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_order_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1718: DB::SelectQueryExpressionAnalyzer::validateOrderByKeyType(std::shared_ptr const&) const::$_0::operator()(DB::IDataType const&) const @ 0x0000000031b0ac76 5. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1729: DB::SelectQueryExpressionAnalyzer::appendOrderBy(DB::ExpressionActionsChain&, bool, bool, std::vector, std::allocator>>&) @ 0x0000000031b071e2 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2257: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b1cbbc 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 12. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:54:54.551750 [ 24861 ] {155bea15-5bf0-40b9-84a8-5a00f1c87a93} executeQuery: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in ORDER BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_order_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 53, line 68) (in query: select * from test order by tuple(d);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1718: DB::SelectQueryExpressionAnalyzer::validateOrderByKeyType(std::shared_ptr const&) const::$_0::operator()(DB::IDataType const&) const @ 0x0000000031b0ac76 5. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1729: DB::SelectQueryExpressionAnalyzer::appendOrderBy(DB::ExpressionActionsChain&, bool, bool, std::vector, std::allocator>>&) @ 0x0000000031b071e2 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2257: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b1cbbc 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 12. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:54:54.555715 [ 24861 ] {} TCPHandler: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in ORDER BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_order_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1718: DB::SelectQueryExpressionAnalyzer::validateOrderByKeyType(std::shared_ptr const&) const::$_0::operator()(DB::IDataType const&) const @ 0x0000000031b0ac76 5. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1729: DB::SelectQueryExpressionAnalyzer::appendOrderBy(DB::ExpressionActionsChain&, bool, bool, std::vector, std::allocator>>&) @ 0x0000000031b071e2 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2257: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b1cbbc 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 12. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:54:54.800842 [ 24861 ] {a125d69c-6b96-4367-b969-85d0d271eb76} executeQuery: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in ORDER BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_order_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 54, line 69) (in query: select * from test order by array(d);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1718: DB::SelectQueryExpressionAnalyzer::validateOrderByKeyType(std::shared_ptr const&) const::$_0::operator()(DB::IDataType const&) const @ 0x0000000031b0ac76 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&) const::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x0000000031b28021 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f25b382 7. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1730: DB::SelectQueryExpressionAnalyzer::appendOrderBy(DB::ExpressionActionsChain&, bool, bool, std::vector, std::allocator>>&) @ 0x0000000031b072ae 8. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2257: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b1cbbc 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 16. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:54:54.806549 [ 24861 ] {} TCPHandler: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in ORDER BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_order_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1718: DB::SelectQueryExpressionAnalyzer::validateOrderByKeyType(std::shared_ptr const&) const::$_0::operator()(DB::IDataType const&) const @ 0x0000000031b0ac76 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&) const::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x0000000031b28021 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f25b382 7. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1730: DB::SelectQueryExpressionAnalyzer::appendOrderBy(DB::ExpressionActionsChain&, bool, bool, std::vector, std::allocator>>&) @ 0x0000000031b072ae 8. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2257: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b1cbbc 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 16. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:54:55.071009 [ 24861 ] {6fb94643-5483-4fbf-b7c1-242db6a3aa5a} executeQuery: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in ORDER BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_order_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 55, line 70) (in query: select * from test order by map('str', d);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1718: DB::SelectQueryExpressionAnalyzer::validateOrderByKeyType(std::shared_ptr const&) const::$_0::operator()(DB::IDataType const&) const @ 0x0000000031b0ac76 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&) const::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x0000000031b28021 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f2c55b5 7. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1730: DB::SelectQueryExpressionAnalyzer::appendOrderBy(DB::ExpressionActionsChain&, bool, bool, std::vector, std::allocator>>&) @ 0x0000000031b072ae 8. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2257: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b1cbbc 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 16. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:54:55.075580 [ 24861 ] {} TCPHandler: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in ORDER BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_order_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1718: DB::SelectQueryExpressionAnalyzer::validateOrderByKeyType(std::shared_ptr const&) const::$_0::operator()(DB::IDataType const&) const @ 0x0000000031b0ac76 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&) const::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x0000000031b28021 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f2c55b5 7. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1730: DB::SelectQueryExpressionAnalyzer::appendOrderBy(DB::ExpressionActionsChain&, bool, bool, std::vector, std::allocator>>&) @ 0x0000000031b072ae 8. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2257: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b1cbbc 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 16. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:54:55.136515 [ 15860 ] {1369dc06-6be2-4c8f-89b7-4c984d13b43e} executeQuery: Code: 116. DB::Exception: Select query is not allowed in columns DEFAULT expression. (THERE_IS_NO_DEFAULT_VALUE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38672) (comment: 00079_defaulted_columns.sql) (query 11, line 14) (in query: create table defaulted (col1 Int8, col2 UInt64 default (SELECT dummy+99 from system.one)) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/ColumnsDescription.cpp:1013: DB::(anonymous namespace)::validateColumnsDefaultsAndGetSampleBlockImpl(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr, bool) @ 0x00000000381e4a11 5. ./build_docker/./src/Storages/ColumnsDescription.cpp:1044: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000381e5633 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:639: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000328cde61 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000328d60b9 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000328fff5d 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:54:55.141534 [ 15860 ] {} TCPHandler: Code: 116. DB::Exception: Select query is not allowed in columns DEFAULT expression. (THERE_IS_NO_DEFAULT_VALUE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/ColumnsDescription.cpp:1013: DB::(anonymous namespace)::validateColumnsDefaultsAndGetSampleBlockImpl(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr, bool) @ 0x00000000381e4a11 5. ./build_docker/./src/Storages/ColumnsDescription.cpp:1044: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000381e5633 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:639: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000328cde61 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000328d60b9 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000328fff5d 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:54:55.357277 [ 24861 ] {420f56ed-a81b-40af-b422-fe6e910a3a4a} executeQuery: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 58, line 75) (in query: select * from test group by d;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1433: DB::SelectQueryExpressionAnalyzer::validateGroupByKeyType(std::shared_ptr const&) const @ 0x0000000031afeb7a 5. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1408: DB::SelectQueryExpressionAnalyzer::appendGroupBy(DB::ExpressionActionsChain&, bool, bool, std::vector, std::allocator>>&) @ 0x0000000031afd49e 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2104: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b166e8 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 12. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:54:55.361459 [ 24861 ] {} TCPHandler: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1433: DB::SelectQueryExpressionAnalyzer::validateGroupByKeyType(std::shared_ptr const&) const @ 0x0000000031afeb7a 5. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1408: DB::SelectQueryExpressionAnalyzer::appendGroupBy(DB::ExpressionActionsChain&, bool, bool, std::vector, std::allocator>>&) @ 0x0000000031afd49e 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2104: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b166e8 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 12. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:54:55.386864 [ 24861 ] {8f127f48-6c01-4fe4-8179-90a5a106caf7} executeQuery: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 59, line 76) (in query: select * from test group by tuple(d);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1433: DB::SelectQueryExpressionAnalyzer::validateGroupByKeyType(std::shared_ptr const&) const @ 0x0000000031afeb7a 5. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1408: DB::SelectQueryExpressionAnalyzer::appendGroupBy(DB::ExpressionActionsChain&, bool, bool, std::vector, std::allocator>>&) @ 0x0000000031afd49e 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2104: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b166e8 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 12. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:54:55.390547 [ 24861 ] {} TCPHandler: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1433: DB::SelectQueryExpressionAnalyzer::validateGroupByKeyType(std::shared_ptr const&) const @ 0x0000000031afeb7a 5. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1408: DB::SelectQueryExpressionAnalyzer::appendGroupBy(DB::ExpressionActionsChain&, bool, bool, std::vector, std::allocator>>&) @ 0x0000000031afd49e 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2104: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b166e8 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 12. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:54:55.614155 [ 24861 ] {3fe91696-a829-448e-97e3-2d1241f52da9} executeQuery: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 60, line 77) (in query: select array(d) from test group by array(d);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1433: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&) const::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x0000000031b27f63 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f25b382 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1442: DB::SelectQueryExpressionAnalyzer::validateGroupByKeyType(std::shared_ptr const&) const @ 0x0000000031afe978 7. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1408: DB::SelectQueryExpressionAnalyzer::appendGroupBy(DB::ExpressionActionsChain&, bool, bool, std::vector, std::allocator>>&) @ 0x0000000031afd49e 8. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2104: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b166e8 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 16. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:54:55.618207 [ 24861 ] {} TCPHandler: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1433: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&) const::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x0000000031b27f63 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f25b382 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1442: DB::SelectQueryExpressionAnalyzer::validateGroupByKeyType(std::shared_ptr const&) const @ 0x0000000031afe978 7. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1408: DB::SelectQueryExpressionAnalyzer::appendGroupBy(DB::ExpressionActionsChain&, bool, bool, std::vector, std::allocator>>&) @ 0x0000000031afd49e 8. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2104: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b166e8 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 16. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:54:55.641635 [ 24861 ] {e7a91ec3-92e5-449c-9d74-0beff416e5b5} executeQuery: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 61, line 78) (in query: select map('str', d) from test group by map('str', d);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1433: DB::SelectQueryExpressionAnalyzer::validateGroupByKeyType(std::shared_ptr const&) const @ 0x0000000031afeb7a 5. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1408: DB::SelectQueryExpressionAnalyzer::appendGroupBy(DB::ExpressionActionsChain&, bool, bool, std::vector, std::allocator>>&) @ 0x0000000031afd49e 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2104: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b166e8 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 12. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:54:55.645817 [ 24861 ] {} TCPHandler: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1433: DB::SelectQueryExpressionAnalyzer::validateGroupByKeyType(std::shared_ptr const&) const @ 0x0000000031afeb7a 5. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1408: DB::SelectQueryExpressionAnalyzer::appendGroupBy(DB::ExpressionActionsChain&, bool, bool, std::vector, std::allocator>>&) @ 0x0000000031afd49e 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2104: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b166e8 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 12. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:54:55.670938 [ 24861 ] {735d9ae6-1e40-4655-be23-13ff34111ce2} executeQuery: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 62, line 79) (in query: select * from test group by grouping sets ((d), ('str'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1433: DB::SelectQueryExpressionAnalyzer::validateGroupByKeyType(std::shared_ptr const&) const @ 0x0000000031afeb7a 5. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1408: DB::SelectQueryExpressionAnalyzer::appendGroupBy(DB::ExpressionActionsChain&, bool, bool, std::vector, std::allocator>>&) @ 0x0000000031afd49e 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2104: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b166e8 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 12. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:54:55.675056 [ 24861 ] {} TCPHandler: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1433: DB::SelectQueryExpressionAnalyzer::validateGroupByKeyType(std::shared_ptr const&) const @ 0x0000000031afeb7a 5. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1408: DB::SelectQueryExpressionAnalyzer::appendGroupBy(DB::ExpressionActionsChain&, bool, bool, std::vector, std::allocator>>&) @ 0x0000000031afd49e 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2104: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b166e8 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 12. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:54:56.617651 [ 24861 ] {04736d0c-b821-4897-a310-1f668f121048} executeQuery: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in ORDER BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_order_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 80, line 105) (in query: select * from test order by d;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4159: DB::QueryAnalyzer::validateSortingKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const::$_0::operator()(DB::IDataType const&) const @ 0x00000000303bc85c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4170: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303b5034 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5641: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030e0c7 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:54:56.621360 [ 24861 ] {} TCPHandler: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in ORDER BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_order_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4159: DB::QueryAnalyzer::validateSortingKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const::$_0::operator()(DB::IDataType const&) const @ 0x00000000303bc85c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4170: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303b5034 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5641: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030e0c7 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:54:56.647767 [ 24861 ] {83944a86-0090-47a3-bee3-50ca962fd886} executeQuery: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in ORDER BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_order_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 81, line 106) (in query: select * from test order by tuple(d);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4159: DB::QueryAnalyzer::validateSortingKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const::$_0::operator()(DB::IDataType const&) const @ 0x00000000303bc85c 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::IdentifierResolveScope const&) const::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x00000000303d6689 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f31ef10 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4171: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303b50f6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5641: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030e0c7 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:54:56.651589 [ 24861 ] {} TCPHandler: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in ORDER BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_order_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4159: DB::QueryAnalyzer::validateSortingKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const::$_0::operator()(DB::IDataType const&) const @ 0x00000000303bc85c 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::IdentifierResolveScope const&) const::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x00000000303d6689 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f31ef10 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4171: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303b50f6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5641: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030e0c7 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:54:56.681072 [ 24861 ] {b7e560c0-90dd-43b0-8546-bd27edfdf3b9} executeQuery: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in ORDER BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_order_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 82, line 107) (in query: select * from test order by array(d);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4159: DB::QueryAnalyzer::validateSortingKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const::$_0::operator()(DB::IDataType const&) const @ 0x00000000303bc85c 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::IdentifierResolveScope const&) const::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x00000000303d6689 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f25b382 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4171: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303b50f6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5641: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030e0c7 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:54:56.684913 [ 24861 ] {} TCPHandler: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in ORDER BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_order_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4159: DB::QueryAnalyzer::validateSortingKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const::$_0::operator()(DB::IDataType const&) const @ 0x00000000303bc85c 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::IdentifierResolveScope const&) const::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x00000000303d6689 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f25b382 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4171: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303b50f6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5641: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030e0c7 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:54:56.729931 [ 24861 ] {4502a0a0-634b-4462-818c-98367b4d6b3a} executeQuery: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in ORDER BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_order_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 83, line 108) (in query: select * from test order by map('str', d);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4159: DB::QueryAnalyzer::validateSortingKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const::$_0::operator()(DB::IDataType const&) const @ 0x00000000303bc85c 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::IdentifierResolveScope const&) const::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x00000000303d6689 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f2c55b5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4171: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303b50f6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5641: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030e0c7 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:54:56.735729 [ 24861 ] {} TCPHandler: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in ORDER BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_order_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4159: DB::QueryAnalyzer::validateSortingKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const::$_0::operator()(DB::IDataType const&) const @ 0x00000000303bc85c 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::IdentifierResolveScope const&) const::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x00000000303d6689 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f2c55b5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4171: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303b50f6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5641: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030e0c7 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:54:56.829843 [ 24861 ] {c7187520-acc4-463d-86ef-01ae2eb36d24} executeQuery: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 86, line 113) (in query: select * from test group by d;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4253: DB::QueryAnalyzer::validateGroupByKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const @ 0x00000000303c05ca 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4236: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x00000000303be141 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5618: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030d524 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:54:56.834601 [ 24861 ] {} TCPHandler: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4253: DB::QueryAnalyzer::validateGroupByKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const @ 0x00000000303c05ca 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4236: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x00000000303be141 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5618: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030d524 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:54:56.869087 [ 24861 ] {ed7b1bde-0552-4760-bd44-53f1cb386de4} executeQuery: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 87, line 114) (in query: select * from test group by tuple(d);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4253: DB::QueryAnalyzer::validateGroupByKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const @ 0x00000000303c05ca 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4236: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x00000000303be141 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5618: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030d524 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:54:56.873105 [ 24861 ] {} TCPHandler: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4253: DB::QueryAnalyzer::validateGroupByKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const @ 0x00000000303c05ca 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4236: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x00000000303be141 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5618: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030d524 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:54:56.904785 [ 24861 ] {fdb31491-d98d-4279-adb7-238656360a02} executeQuery: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 88, line 115) (in query: select array(d) from test group by array(d);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4253: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::IdentifierResolveScope const&) const::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x00000000303d6823 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f25b382 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4262: DB::QueryAnalyzer::validateGroupByKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const @ 0x00000000303c044f 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4236: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x00000000303be141 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5618: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030d524 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:54:56.908978 [ 24861 ] {} TCPHandler: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4253: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::IdentifierResolveScope const&) const::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x00000000303d6823 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f25b382 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4262: DB::QueryAnalyzer::validateGroupByKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const @ 0x00000000303c044f 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4236: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x00000000303be141 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5618: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030d524 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:54:56.950612 [ 24861 ] {0abe15e4-65e9-41a5-99ce-a66741751139} executeQuery: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 89, line 116) (in query: select map('str', d) from test group by map('str', d);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4253: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::IdentifierResolveScope const&) const::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x00000000303d6823 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f2c55b5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4262: DB::QueryAnalyzer::validateGroupByKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const @ 0x00000000303c044f 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4236: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x00000000303be141 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5618: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030d524 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:54:56.957718 [ 24861 ] {} TCPHandler: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4253: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::IdentifierResolveScope const&) const::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x00000000303d6823 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f2c55b5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4262: DB::QueryAnalyzer::validateGroupByKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const @ 0x00000000303c044f 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4236: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x00000000303be141 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5618: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030d524 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:54:56.987713 [ 24861 ] {2761a3e4-2ba4-4cd6-a13c-e56bb9d9c555} executeQuery: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 90, line 117) (in query: select * from test group by grouping sets ((d), ('str'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4253: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x00000000303be728 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5618: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030d524 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:54:56.992484 [ 24861 ] {} TCPHandler: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4253: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x00000000303be728 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5618: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030d524 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:54:57.704765 [ 2135 ] {6d1a20ce-e9bf-43a1-85f7-543f0b0cec7e} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 20.12 MiB (attempt to allocate chunk of 1.50 MiB bytes), maximum: 19.07 MiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38724) (comment: 01655_plan_optimizations_optimize_read_in_window_order_long.sh) (query 1, line 1) (in query: select n, sum(x) OVER (PARTITION BY n ORDER BY x ROWS BETWEEN 100 PRECEDING AND CURRENT ROW) from test_01655_plan_optimizations_optimize_read_in_window_order_long_n_x SETTINGS optimize_read_in_order=0, optimize_read_in_window_order=0, max_memory_usage=20000000, max_threads=1 format Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f53cbed 8. ./src/Common/PODArray.h:118: auto DB::ColumnVector::updatePermutation(DB::IColumn::PermutationSortDirection, DB::IColumn::PermutationSortStability, unsigned long, int, DB::PODArray, 63ul, 64ul>&, std::vector>&) const::'lambda'(auto, auto, auto)::operator()::less>(auto, auto, auto) const @ 0x0000000037dbf1a7 9. ./src/Columns/IColumnImpl.h:154: void DB::IColumn::updatePermutationImpl::less, DB::ColumnVector::equals, DB::ColumnVector::updatePermutation(DB::IColumn::PermutationSortDirection, DB::IColumn::PermutationSortStability, unsigned long, int, DB::PODArray, 63ul, 64ul>&, std::vector>&) const::'lambda'(auto, auto, auto), DB::ColumnVector::updatePermutation(DB::IColumn::PermutationSortDirection, DB::IColumn::PermutationSortStability, unsigned long, int, DB::PODArray, 63ul, 64ul>&, std::vector>&) const::'lambda'(auto, auto, auto, auto)>(unsigned long, DB::PODArray, 63ul, 64ul>&, std::vector>&, auto, auto, auto, auto) const @ 0x0000000037a88251 10. ./build_docker/./src/Columns/ColumnVector.cpp:386: DB::ColumnVector::updatePermutation(DB::IColumn::PermutationSortDirection, DB::IColumn::PermutationSortStability, unsigned long, int, DB::PODArray, 63ul, 64ul>&, std::vector>&) const @ 0x0000000037a87b18 11. ./build_docker/./src/Interpreters/sortBlock.cpp:195: DB::(anonymous namespace)::getBlockSortPermutationImpl(DB::Block const&, DB::SortDescription const&, DB::IColumn::PermutationSortStability, unsigned long, DB::PODArray, 63ul, 64ul>&) @ 0x0000000033909361 12. ./build_docker/./src/Interpreters/sortBlock.cpp:339: DB::sortBlock(DB::Block&, DB::SortDescription const&, unsigned long) @ 0x00000000339079ea 13. ./build_docker/./src/Processors/Transforms/PartialSortingTransform.cpp:137: DB::PartialSortingTransform::transform(DB::Chunk&) @ 0x000000003babcdc5 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:54:57.732328 [ 2135 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 20.12 MiB (attempt to allocate chunk of 1.50 MiB bytes), maximum: 19.07 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f53cbed 8. ./src/Common/PODArray.h:118: auto DB::ColumnVector::updatePermutation(DB::IColumn::PermutationSortDirection, DB::IColumn::PermutationSortStability, unsigned long, int, DB::PODArray, 63ul, 64ul>&, std::vector>&) const::'lambda'(auto, auto, auto)::operator()::less>(auto, auto, auto) const @ 0x0000000037dbf1a7 9. ./src/Columns/IColumnImpl.h:154: void DB::IColumn::updatePermutationImpl::less, DB::ColumnVector::equals, DB::ColumnVector::updatePermutation(DB::IColumn::PermutationSortDirection, DB::IColumn::PermutationSortStability, unsigned long, int, DB::PODArray, 63ul, 64ul>&, std::vector>&) const::'lambda'(auto, auto, auto), DB::ColumnVector::updatePermutation(DB::IColumn::PermutationSortDirection, DB::IColumn::PermutationSortStability, unsigned long, int, DB::PODArray, 63ul, 64ul>&, std::vector>&) const::'lambda'(auto, auto, auto, auto)>(unsigned long, DB::PODArray, 63ul, 64ul>&, std::vector>&, auto, auto, auto, auto) const @ 0x0000000037a88251 10. ./build_docker/./src/Columns/ColumnVector.cpp:386: DB::ColumnVector::updatePermutation(DB::IColumn::PermutationSortDirection, DB::IColumn::PermutationSortStability, unsigned long, int, DB::PODArray, 63ul, 64ul>&, std::vector>&) const @ 0x0000000037a87b18 11. ./build_docker/./src/Interpreters/sortBlock.cpp:195: DB::(anonymous namespace)::getBlockSortPermutationImpl(DB::Block const&, DB::SortDescription const&, DB::IColumn::PermutationSortStability, unsigned long, DB::PODArray, 63ul, 64ul>&) @ 0x0000000033909361 12. ./build_docker/./src/Interpreters/sortBlock.cpp:339: DB::sortBlock(DB::Block&, DB::SortDescription const&, unsigned long) @ 0x00000000339079ea 13. ./build_docker/./src/Processors/Transforms/PartialSortingTransform.cpp:137: DB::PartialSortingTransform::transform(DB::Chunk&) @ 0x000000003babcdc5 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:54:57.949255 [ 24861 ] {150c9b6a-c7eb-44a0-86a9-680f6979a376} executeQuery: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in ORDER BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_order_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 105, line 138) (in query: select * from test order by d;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1718: DB::SelectQueryExpressionAnalyzer::validateOrderByKeyType(std::shared_ptr const&) const::$_0::operator()(DB::IDataType const&) const @ 0x0000000031b0ac76 5. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1729: DB::SelectQueryExpressionAnalyzer::appendOrderBy(DB::ExpressionActionsChain&, bool, bool, std::vector, std::allocator>>&) @ 0x0000000031b071e2 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2257: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b1cbbc 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 12. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:54:57.953482 [ 24861 ] {} TCPHandler: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in ORDER BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_order_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1718: DB::SelectQueryExpressionAnalyzer::validateOrderByKeyType(std::shared_ptr const&) const::$_0::operator()(DB::IDataType const&) const @ 0x0000000031b0ac76 5. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1729: DB::SelectQueryExpressionAnalyzer::appendOrderBy(DB::ExpressionActionsChain&, bool, bool, std::vector, std::allocator>>&) @ 0x0000000031b071e2 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2257: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b1cbbc 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 12. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:54:57.979699 [ 24861 ] {3b23e6b8-f87d-4639-b641-153ceb5d003b} executeQuery: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in ORDER BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_order_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 106, line 139) (in query: select * from test order by tuple(d);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1718: DB::SelectQueryExpressionAnalyzer::validateOrderByKeyType(std::shared_ptr const&) const::$_0::operator()(DB::IDataType const&) const @ 0x0000000031b0ac76 5. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1729: DB::SelectQueryExpressionAnalyzer::appendOrderBy(DB::ExpressionActionsChain&, bool, bool, std::vector, std::allocator>>&) @ 0x0000000031b071e2 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2257: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b1cbbc 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 12. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:54:57.984008 [ 24861 ] {} TCPHandler: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in ORDER BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_order_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1718: DB::SelectQueryExpressionAnalyzer::validateOrderByKeyType(std::shared_ptr const&) const::$_0::operator()(DB::IDataType const&) const @ 0x0000000031b0ac76 5. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1729: DB::SelectQueryExpressionAnalyzer::appendOrderBy(DB::ExpressionActionsChain&, bool, bool, std::vector, std::allocator>>&) @ 0x0000000031b071e2 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2257: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b1cbbc 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 12. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:54:58.011846 [ 24861 ] {e223da37-ae2a-4e78-9fd5-b3399375f53e} executeQuery: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in ORDER BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_order_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 107, line 140) (in query: select * from test order by array(d);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1718: DB::SelectQueryExpressionAnalyzer::validateOrderByKeyType(std::shared_ptr const&) const::$_0::operator()(DB::IDataType const&) const @ 0x0000000031b0ac76 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&) const::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x0000000031b28021 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f25b382 7. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1730: DB::SelectQueryExpressionAnalyzer::appendOrderBy(DB::ExpressionActionsChain&, bool, bool, std::vector, std::allocator>>&) @ 0x0000000031b072ae 8. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2257: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b1cbbc 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 16. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:54:58.016197 [ 24861 ] {} TCPHandler: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in ORDER BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_order_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1718: DB::SelectQueryExpressionAnalyzer::validateOrderByKeyType(std::shared_ptr const&) const::$_0::operator()(DB::IDataType const&) const @ 0x0000000031b0ac76 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&) const::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x0000000031b28021 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f25b382 7. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1730: DB::SelectQueryExpressionAnalyzer::appendOrderBy(DB::ExpressionActionsChain&, bool, bool, std::vector, std::allocator>>&) @ 0x0000000031b072ae 8. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2257: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b1cbbc 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 16. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:54:58.044705 [ 24861 ] {16059ca4-0a05-4299-8643-9a3a2b7543fc} executeQuery: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in ORDER BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_order_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 108, line 141) (in query: select * from test order by map('str', d);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1718: DB::SelectQueryExpressionAnalyzer::validateOrderByKeyType(std::shared_ptr const&) const::$_0::operator()(DB::IDataType const&) const @ 0x0000000031b0ac76 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&) const::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x0000000031b28021 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f2c55b5 7. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1730: DB::SelectQueryExpressionAnalyzer::appendOrderBy(DB::ExpressionActionsChain&, bool, bool, std::vector, std::allocator>>&) @ 0x0000000031b072ae 8. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2257: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b1cbbc 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 16. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:54:58.048977 [ 24861 ] {} TCPHandler: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in ORDER BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_order_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1718: DB::SelectQueryExpressionAnalyzer::validateOrderByKeyType(std::shared_ptr const&) const::$_0::operator()(DB::IDataType const&) const @ 0x0000000031b0ac76 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&) const::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x0000000031b28021 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f2c55b5 7. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1730: DB::SelectQueryExpressionAnalyzer::appendOrderBy(DB::ExpressionActionsChain&, bool, bool, std::vector, std::allocator>>&) @ 0x0000000031b072ae 8. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2257: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b1cbbc 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 16. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:54:58.143188 [ 24861 ] {7666e9dc-2d7d-44c9-9b64-728f7d8a903e} executeQuery: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 111, line 146) (in query: select * from test group by d;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1433: DB::SelectQueryExpressionAnalyzer::validateGroupByKeyType(std::shared_ptr const&) const @ 0x0000000031afeb7a 5. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1408: DB::SelectQueryExpressionAnalyzer::appendGroupBy(DB::ExpressionActionsChain&, bool, bool, std::vector, std::allocator>>&) @ 0x0000000031afd49e 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2104: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b166e8 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 12. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:54:58.149110 [ 24861 ] {} TCPHandler: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1433: DB::SelectQueryExpressionAnalyzer::validateGroupByKeyType(std::shared_ptr const&) const @ 0x0000000031afeb7a 5. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1408: DB::SelectQueryExpressionAnalyzer::appendGroupBy(DB::ExpressionActionsChain&, bool, bool, std::vector, std::allocator>>&) @ 0x0000000031afd49e 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2104: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b166e8 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 12. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:54:58.177049 [ 24861 ] {ab9f9899-befa-4b6d-839a-127d3dd6602f} executeQuery: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 112, line 147) (in query: select * from test group by tuple(d);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1433: DB::SelectQueryExpressionAnalyzer::validateGroupByKeyType(std::shared_ptr const&) const @ 0x0000000031afeb7a 5. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1408: DB::SelectQueryExpressionAnalyzer::appendGroupBy(DB::ExpressionActionsChain&, bool, bool, std::vector, std::allocator>>&) @ 0x0000000031afd49e 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2104: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b166e8 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 12. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:54:58.182371 [ 24861 ] {} TCPHandler: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1433: DB::SelectQueryExpressionAnalyzer::validateGroupByKeyType(std::shared_ptr const&) const @ 0x0000000031afeb7a 5. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1408: DB::SelectQueryExpressionAnalyzer::appendGroupBy(DB::ExpressionActionsChain&, bool, bool, std::vector, std::allocator>>&) @ 0x0000000031afd49e 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2104: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b166e8 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 12. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:54:58.208240 [ 24861 ] {205357e0-79e9-419f-b8de-e075244dfadd} executeQuery: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 113, line 148) (in query: select array(d) from test group by array(d);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1433: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&) const::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x0000000031b27f63 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f25b382 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1442: DB::SelectQueryExpressionAnalyzer::validateGroupByKeyType(std::shared_ptr const&) const @ 0x0000000031afe978 7. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1408: DB::SelectQueryExpressionAnalyzer::appendGroupBy(DB::ExpressionActionsChain&, bool, bool, std::vector, std::allocator>>&) @ 0x0000000031afd49e 8. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2104: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b166e8 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 16. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:54:58.212436 [ 24861 ] {} TCPHandler: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1433: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&) const::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x0000000031b27f63 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f25b382 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1442: DB::SelectQueryExpressionAnalyzer::validateGroupByKeyType(std::shared_ptr const&) const @ 0x0000000031afe978 7. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1408: DB::SelectQueryExpressionAnalyzer::appendGroupBy(DB::ExpressionActionsChain&, bool, bool, std::vector, std::allocator>>&) @ 0x0000000031afd49e 8. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2104: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b166e8 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 16. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:54:58.242073 [ 24861 ] {b54550af-ae53-4651-b7e6-e4d7d89de845} executeQuery: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 114, line 149) (in query: select map('str', d) from test group by map('str', d);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1433: DB::SelectQueryExpressionAnalyzer::validateGroupByKeyType(std::shared_ptr const&) const @ 0x0000000031afeb7a 5. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1408: DB::SelectQueryExpressionAnalyzer::appendGroupBy(DB::ExpressionActionsChain&, bool, bool, std::vector, std::allocator>>&) @ 0x0000000031afd49e 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2104: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b166e8 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 12. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:54:58.246670 [ 24861 ] {} TCPHandler: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1433: DB::SelectQueryExpressionAnalyzer::validateGroupByKeyType(std::shared_ptr const&) const @ 0x0000000031afeb7a 5. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1408: DB::SelectQueryExpressionAnalyzer::appendGroupBy(DB::ExpressionActionsChain&, bool, bool, std::vector, std::allocator>>&) @ 0x0000000031afd49e 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2104: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b166e8 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 12. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:54:58.275577 [ 24861 ] {b61281c1-a115-495b-a4a6-1657e95a6f30} executeQuery: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60250) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 115, line 150) (in query: select * from test group by grouping sets ((d), ('str'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1433: DB::SelectQueryExpressionAnalyzer::validateGroupByKeyType(std::shared_ptr const&) const @ 0x0000000031afeb7a 5. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1408: DB::SelectQueryExpressionAnalyzer::appendGroupBy(DB::ExpressionActionsChain&, bool, bool, std::vector, std::allocator>>&) @ 0x0000000031afd49e 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2104: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b166e8 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 12. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:54:58.281565 [ 24861 ] {} TCPHandler: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1433: DB::SelectQueryExpressionAnalyzer::validateGroupByKeyType(std::shared_ptr const&) const @ 0x0000000031afeb7a 5. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1408: DB::SelectQueryExpressionAnalyzer::appendGroupBy(DB::ExpressionActionsChain&, bool, bool, std::vector, std::allocator>>&) @ 0x0000000031afd49e 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2104: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b166e8 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 12. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:54:58.551601 [ 9254 ] {cc8a717a-4c62-4d8c-96a1-62f12ccb4f75} executeQuery: Code: 277. DB::Exception: Primary key (k) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:49204) (comment: 02946_parallel_replicas_force_primary_key.sql) (query 16, line 38) (in query: SELECT `__table1`.`k` AS `k`, count() AS `count()` FROM `test_1itlygj2`.`t1` AS `__table1` GROUP BY `__table1`.`k` ORDER BY `__table1`.`k` ASC), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x00000000384e6aaa 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1754: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003c1a706b 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003c1a5d42 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003c1a54d7 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003c1bc5b8 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1c2fdc 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049298 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 2025.06.13 08:54:58.552135 [ 2137 ] {72b71270-e26d-4244-8e6a-3b200d0f14be} executeQuery: Code: 277. DB::Exception: Primary key (k) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:49946) (comment: 02946_parallel_replicas_force_primary_key.sql) (query 16, line 38) (in query: SELECT `__table1`.`k` AS `k`, count() AS `count()` FROM `test_1itlygj2`.`t1` AS `__table1` GROUP BY `__table1`.`k` ORDER BY `__table1`.`k` ASC), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x00000000384e6aaa 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1754: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003c1a706b 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003c1a5d42 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003c1a54d7 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003c1bc5b8 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1c2fdc 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049298 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 2025.06.13 08:54:58.552351 [ 2138 ] {9e4cddd4-1bb2-4805-aed3-ac5134079a3f} executeQuery: Code: 277. DB::Exception: Primary key (k) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:37702) (comment: 02946_parallel_replicas_force_primary_key.sql) (query 16, line 38) (in query: SELECT `__table1`.`k` AS `k`, count() AS `count()` FROM `test_1itlygj2`.`t1` AS `__table1` GROUP BY `__table1`.`k` ORDER BY `__table1`.`k` ASC), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x00000000384e6aaa 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1754: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003c1a706b 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003c1a5d42 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003c1a54d7 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003c1bc5b8 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1c2fdc 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049298 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 2025.06.13 08:54:58.555846 [ 9254 ] {} TCPHandler: Code: 277. DB::Exception: Primary key (k) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x00000000384e6aaa 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1754: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003c1a706b 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003c1a5d42 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003c1a54d7 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003c1bc5b8 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1c2fdc 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049298 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 2025.06.13 08:54:58.556707 [ 2137 ] {} TCPHandler: Code: 277. DB::Exception: Primary key (k) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x00000000384e6aaa 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1754: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003c1a706b 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003c1a5d42 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003c1a54d7 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003c1bc5b8 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1c2fdc 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049298 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 2025.06.13 08:54:58.558977 [ 2138 ] {} TCPHandler: Code: 277. DB::Exception: Primary key (k) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x00000000384e6aaa 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1754: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003c1a706b 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003c1a5d42 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003c1a54d7 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003c1bc5b8 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1c2fdc 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049298 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 2025.06.13 08:54:58.650296 [ 24844 ] {44929973-e27f-499c-9749-925b3dd29dd0} executeQuery: Code: 277. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Primary key (k) is not used and setting 'force_primary_key' is set. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x00000000384e6aaa 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1754: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003c1a706b 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003c1a5d42 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003c1a54d7 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003c1bc5b8 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1c2fdc 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049298 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 : While executing Remote. (INDEX_NOT_USED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38712) (comment: 02946_parallel_replicas_force_primary_key.sql) (query 16, line 38) (in query: -- parallel replicas, primary key is NOT used SELECT k, count() FROM t1 GROUP BY k ORDER BY k SETTINGS force_primary_key = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f893977 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003a97bf4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003a99a03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003aa87c78 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f23f654 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 2025.06.13 08:54:58.664622 [ 24844 ] {} TCPHandler: Code: 277. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Primary key (k) is not used and setting 'force_primary_key' is set. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x00000000384e6aaa 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1754: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003c1a706b 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003c1a5d42 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003c1a54d7 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003c1bc5b8 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1c2fdc 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049298 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 : While executing Remote. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f893977 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003a97bf4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003a99a03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003aa87c78 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f23f654 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:54:59.241718 [ 405 ] {d3b5e758-f1b1-4222-af4c-d0daff7c22d6} executeQuery: Code: 6. DB::Exception: Neither IPv4 nor IPv6 address: 'unparsable': In scope SELECT isIPAddressInRange('unparsable', '127.0.0.0/8'). (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38718) (comment: 01774_ip_address_in_range.sql) (query 34, line 54) (in query: SELECT isIPAddressInRange('unparsable', '127.0.0.0/8');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000115e1d0a 4. (anonymous namespace)::IPAddressVariant::IPAddressVariant(std::basic_string_view>) @ 0x000000001283fa56 5. DB::FunctionIsIPAddressContainedIn::executeImpl(DB::ColumnConst const&, DB::ColumnConst const&, unsigned long) @ 0x0000000012842466 6. DB::FunctionIsIPAddressContainedIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000128417ac 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 08:54:59.246300 [ 405 ] {} TCPHandler: Code: 6. DB::Exception: Neither IPv4 nor IPv6 address: 'unparsable': In scope SELECT isIPAddressInRange('unparsable', '127.0.0.0/8'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000115e1d0a 4. (anonymous namespace)::IPAddressVariant::IPAddressVariant(std::basic_string_view>) @ 0x000000001283fa56 5. DB::FunctionIsIPAddressContainedIn::executeImpl(DB::ColumnConst const&, DB::ColumnConst const&, unsigned long) @ 0x0000000012842466 6. DB::FunctionIsIPAddressContainedIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000128417ac 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 08:54:59.522508 [ 405 ] {7bcad94b-f4f3-4af6-a2b7-8ce7f1e3094f} executeQuery: Code: 6. DB::Exception: The text does not contain '/': unparsable: In scope SELECT isIPAddressInRange('127.0.0.1', 'unparsable'). (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38718) (comment: 01774_ip_address_in_range.sql) (query 35, line 55) (in query: SELECT isIPAddressInRange('127.0.0.1', 'unparsable');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. (anonymous namespace)::parseIPWithCIDR(std::basic_string_view>) @ 0x00000000128402ba 5. DB::FunctionIsIPAddressContainedIn::executeImpl(DB::ColumnConst const&, DB::ColumnConst const&, unsigned long) @ 0x0000000012842504 6. DB::FunctionIsIPAddressContainedIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000128417ac 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 08:54:59.526611 [ 405 ] {} TCPHandler: Code: 6. DB::Exception: The text does not contain '/': unparsable: In scope SELECT isIPAddressInRange('127.0.0.1', 'unparsable'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. (anonymous namespace)::parseIPWithCIDR(std::basic_string_view>) @ 0x00000000128402ba 5. DB::FunctionIsIPAddressContainedIn::executeImpl(DB::ColumnConst const&, DB::ColumnConst const&, unsigned long) @ 0x0000000012842504 6. DB::FunctionIsIPAddressContainedIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000128417ac 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 08:54:59.882257 [ 405 ] {67091530-ba41-4c49-8fb8-b3bb17553016} executeQuery: Code: 43. DB::Exception: The arguments of function isIPAddressInRange must be String: In scope SELECT isIPAddressInRange(100, '127.0.0.0/8'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38718) (comment: 01774_ip_address_in_range.sql) (query 37, line 59) (in query: SELECT isIPAddressInRange(100, '127.0.0.0/8');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::FunctionIsIPAddressContainedIn::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000012841f39 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:54:59.886650 [ 405 ] {} TCPHandler: Code: 43. DB::Exception: The arguments of function isIPAddressInRange must be String: In scope SELECT isIPAddressInRange(100, '127.0.0.0/8'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::FunctionIsIPAddressContainedIn::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000012841f39 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:54:59.910910 [ 405 ] {4b62f04f-732c-400e-a08c-62e933b6da44} executeQuery: Code: 43. DB::Exception: The arguments of function isIPAddressInRange must be String: In scope SELECT isIPAddressInRange(NULL, '127.0.0.0/8'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38718) (comment: 01774_ip_address_in_range.sql) (query 38, line 60) (in query: SELECT isIPAddressInRange(NULL, '127.0.0.0/8');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::FunctionIsIPAddressContainedIn::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000012841f39 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:54:59.915560 [ 405 ] {} TCPHandler: Code: 43. DB::Exception: The arguments of function isIPAddressInRange must be String: In scope SELECT isIPAddressInRange(NULL, '127.0.0.0/8'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::FunctionIsIPAddressContainedIn::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000012841f39 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:54:59.942989 [ 405 ] {1f300b2b-beec-4ac3-90e0-d228a110aea7} executeQuery: Code: 43. DB::Exception: The arguments of function isIPAddressInRange must be String: In scope SELECT isIPAddressInRange(CAST(NULL, 'Nullable(String)'), '127.0.0.0/8'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38718) (comment: 01774_ip_address_in_range.sql) (query 39, line 61) (in query: SELECT isIPAddressInRange(CAST(NULL, 'Nullable(String)'), '127.0.0.0/8');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::FunctionIsIPAddressContainedIn::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000012841f39 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:54:59.947670 [ 405 ] {} TCPHandler: Code: 43. DB::Exception: The arguments of function isIPAddressInRange must be String: In scope SELECT isIPAddressInRange(CAST(NULL, 'Nullable(String)'), '127.0.0.0/8'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::FunctionIsIPAddressContainedIn::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000012841f39 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:54:59.974231 [ 405 ] {afd89d10-1d13-4db1-b552-5bc497c8463b} executeQuery: Code: 43. DB::Exception: The arguments of function isIPAddressInRange must be String: In scope SELECT isIPAddressInRange('127.0.0.1', 100). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38718) (comment: 01774_ip_address_in_range.sql) (query 40, line 62) (in query: SELECT isIPAddressInRange('127.0.0.1', 100);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::FunctionIsIPAddressContainedIn::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000012841f39 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:54:59.979061 [ 405 ] {} TCPHandler: Code: 43. DB::Exception: The arguments of function isIPAddressInRange must be String: In scope SELECT isIPAddressInRange('127.0.0.1', 100). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::FunctionIsIPAddressContainedIn::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000012841f39 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:55:00.005017 [ 405 ] {58976d2a-73be-41aa-858e-661787d535d0} executeQuery: Code: 43. DB::Exception: The arguments of function isIPAddressInRange must be String: In scope SELECT isIPAddressInRange(100, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38718) (comment: 01774_ip_address_in_range.sql) (query 41, line 63) (in query: SELECT isIPAddressInRange(100, NULL);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::FunctionIsIPAddressContainedIn::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000012841f39 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:55:00.009961 [ 405 ] {} TCPHandler: Code: 43. DB::Exception: The arguments of function isIPAddressInRange must be String: In scope SELECT isIPAddressInRange(100, NULL). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::FunctionIsIPAddressContainedIn::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000012841f39 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:55:00.042974 [ 405 ] {68acbc23-0d99-41c5-8cd7-d25921371585} executeQuery: Code: 43. DB::Exception: The arguments of function isIPAddressInRange must be String: In scope WITH arrayJoin([NULL, NULL, NULL, NULL]) AS prefix SELECT isIPAddressInRange([NULL, NULL, 0, 255, 0], prefix). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38718) (comment: 01774_ip_address_in_range.sql) (query 42, line 64) (in query: WITH arrayJoin([NULL, NULL, NULL, NULL]) AS prefix SELECT isIPAddressInRange([NULL, NULL, 0, 255, 0], prefix);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::FunctionIsIPAddressContainedIn::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000012841f39 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:55:00.046971 [ 405 ] {} TCPHandler: Code: 43. DB::Exception: The arguments of function isIPAddressInRange must be String: In scope WITH arrayJoin([NULL, NULL, NULL, NULL]) AS prefix SELECT isIPAddressInRange([NULL, NULL, 0, 255, 0], prefix). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::FunctionIsIPAddressContainedIn::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000012841f39 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:55:00.312816 [ 24857 ] {6ba9fc8a-420d-4605-b05d-502248a9ac4f} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'tabB' in scope SELECT date, if(colA IN (SELECT colB FROM tabC), 0, colA) AS colX FROM tabB. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38784) (comment: 01717_global_with_subquery_fix.sql) (query 1, line 3) (in query: WITH (SELECT count(distinct colU) from tabA) AS withA, (SELECT count(distinct colU) from tabA) AS withB SELECT withA / withB AS ratio FROM (SELECT date AS period, colX FROM (SELECT date, if(colA IN (SELECT colB FROM tabC), 0, colA) AS colX FROM tabB) AS tempB GROUP BY period, colX) AS main;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032612b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8db2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032612b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8db2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 29. ? @ 0x00007f5206343ac3 30. ? @ 0x00007f52063d5850 2025.06.13 08:55:00.318600 [ 24857 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'tabB' in scope SELECT date, if(colA IN (SELECT colB FROM tabC), 0, colA) AS colX FROM tabB. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032612b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8db2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032612b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8db2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 29. ? @ 0x00007f5206343ac3 30. ? @ 0x00007f52063d5850 2025.06.13 08:55:01.593380 [ 24857 ] {434ed261-370b-4541-a36c-dd52783e780c} executeQuery: Code: 291. DB::Exception: Cannot log errors in path `/var/lib/clickhouse/user_files/../error_file`, because it is not inside `/var/lib/clickhouse/user_files/`: While executing File. (DATABASE_ACCESS_DENIED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38828) (comment: 02453_check_path_in_errors_logger.sql) (query 2, line 2) (in query: select * from file(02453_data.jsonl, auto, 'x UInt32') settings input_format_allow_errors_num=1, input_format_record_errors_file_path='../error_file';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001a317bad 4. ./build_docker/./src/Processors/Formats/InputFormatErrorsLogger.cpp:50: DB::InputFormatErrorsLogger::InputFormatErrorsLogger(std::shared_ptr const&) @ 0x000000003b11943c 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::FormatFactory::getInput(String const&, DB::ReadBuffer&, DB::Block const&, std::shared_ptr const&, unsigned long, std::optional const&, std::optional, std::optional, bool, DB::CompressionMethod, bool) const @ 0x000000003ae8b69d 6. ./build_docker/./src/Storages/StorageFile.cpp:1443: DB::StorageFileSource::generate() @ 0x0000000038415099 7. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 8. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 13. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 08:55:01.600577 [ 24857 ] {} TCPHandler: Code: 291. DB::Exception: Cannot log errors in path `/var/lib/clickhouse/user_files/../error_file`, because it is not inside `/var/lib/clickhouse/user_files/`: While executing File. (DATABASE_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001a317bad 4. ./build_docker/./src/Processors/Formats/InputFormatErrorsLogger.cpp:50: DB::InputFormatErrorsLogger::InputFormatErrorsLogger(std::shared_ptr const&) @ 0x000000003b11943c 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::FormatFactory::getInput(String const&, DB::ReadBuffer&, DB::Block const&, std::shared_ptr const&, unsigned long, std::optional const&, std::optional, std::optional, bool, DB::CompressionMethod, bool) const @ 0x000000003ae8b69d 6. ./build_docker/./src/Storages/StorageFile.cpp:1443: DB::StorageFileSource::generate() @ 0x0000000038415099 7. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 8. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 13. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:55:02.465491 [ 15861 ] {f29aa8a1-b1d4-4fb3-abf1-bf1dc2cd3fa8} executeQuery: Code: 80. DB::Exception: Secondary index 't_constant_index' cannot contain constants. (INCORRECT_QUERY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38854) (comment: 02670_constant_skip_index.sql) (query 2, line 4) (in query: CREATE TABLE t_constant_index (`id` UInt64, INDEX t_constant_index 'foo' TYPE set(2) GRANULARITY 1) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 60411, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 330841463, compact_parts_max_granules_to_buffer = 9, compact_parts_merge_max_bytes_to_prefetch_part = 3585737, merge_max_block_size = 22233, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 483910, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 6453000406, index_granularity_bytes = 25916057, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 21020, primary_key_compress_block_size = 45000, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/MergeTree/MergeTreeIndices.cpp:97: DB::MergeTreeIndexFactory::validate(DB::IndexDescription const&, bool) const @ 0x0000000039bece59 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:808: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000039776bdd 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:869: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000003975fc87 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:517: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000003975c601 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a38dc5f 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a38d037 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37f002 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:55:02.470411 [ 15861 ] {} TCPHandler: Code: 80. DB::Exception: Secondary index 't_constant_index' cannot contain constants. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/MergeTree/MergeTreeIndices.cpp:97: DB::MergeTreeIndexFactory::validate(DB::IndexDescription const&, bool) const @ 0x0000000039bece59 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:808: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000039776bdd 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:869: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000003975fc87 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:517: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000003975c601 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a38dc5f 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a38d037 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37f002 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:55:02.825574 [ 15861 ] {0bc62c34-0b81-4437-9903-86847da92866} executeQuery: Code: 36. DB::Exception: Expression must be deterministic but it contains non-deterministic part `rand()`: for secondary index 't_constant_index'. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38854) (comment: 02670_constant_skip_index.sql) (query 3, line 11) (in query: CREATE TABLE t_constant_index (`id` UInt64, INDEX t_constant_index id + rand() TYPE set(2) GRANULARITY 1) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 60411, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 330841463, compact_parts_max_granules_to_buffer = 9, compact_parts_merge_max_bytes_to_prefetch_part = 3585737, merge_max_block_size = 22233, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 483910, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 6453000406, index_granularity_bytes = 25916057, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 21020, primary_key_compress_block_size = 45000, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1502: DB::ActionsDAG::assertDeterministic() const @ 0x0000000030123930 5. ./build_docker/./src/Interpreters/ExpressionActions.cpp:837: DB::ExpressionActions::assertDeterministic() const @ 0x0000000031a8e7c9 6. ./build_docker/./src/Storages/MergeTree/MergeTreeIndices.cpp:87: DB::MergeTreeIndexFactory::validate(DB::IndexDescription const&, bool) const @ 0x0000000039becb0e 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:808: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000039776bdd 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:869: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000003975fc87 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:517: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000003975c601 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a38dc5f 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a38d037 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37f002 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:55:02.830194 [ 15861 ] {} TCPHandler: Code: 36. DB::Exception: Expression must be deterministic but it contains non-deterministic part `rand()`: for secondary index 't_constant_index'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1502: DB::ActionsDAG::assertDeterministic() const @ 0x0000000030123930 5. ./build_docker/./src/Interpreters/ExpressionActions.cpp:837: DB::ExpressionActions::assertDeterministic() const @ 0x0000000031a8e7c9 6. ./build_docker/./src/Storages/MergeTree/MergeTreeIndices.cpp:87: DB::MergeTreeIndexFactory::validate(DB::IndexDescription const&, bool) const @ 0x0000000039becb0e 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:808: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000039776bdd 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:869: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000003975fc87 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:517: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000003975c601 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a38dc5f 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a38d037 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37f002 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:55:04.010097 [ 15867 ] {3bfaf8a6-5518-43ad-ba1b-4041302073da} executeQuery: Code: 36. DB::Exception: Frame start offset for 'RANGE' frame must be a nonnegative 32-bit integer, '0.' of type 'Float64' given. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37734) (comment: 02833_window_func_range_offset.sql) (query 1, line 1) (in query: -- invalid start offset with RANGE SELECT count() OVER (ORDER BY 3.4028234663852886e38 RANGE BETWEEN 0.0 PRECEDING AND UNBOUNDED FOLLOWING);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x0000000033647a57 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:100: DB::WindowFrame::checkValid() const @ 0x0000000033646df0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2564: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303b14aa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3290: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037c521 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:55:04.016588 [ 15867 ] {} TCPHandler: Code: 36. DB::Exception: Frame start offset for 'RANGE' frame must be a nonnegative 32-bit integer, '0.' of type 'Float64' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x0000000033647a57 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:100: DB::WindowFrame::checkValid() const @ 0x0000000033646df0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2564: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303b14aa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3290: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037c521 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:55:04.045017 [ 15867 ] {9d704126-7899-4e30-a99b-e8a73930e6e1} executeQuery: Code: 36. DB::Exception: Frame start offset for 'RANGE' frame must be a nonnegative 32-bit integer, 'nan' of type 'Float64' given. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37734) (comment: 02833_window_func_range_offset.sql) (query 2, line 3) (in query: SELECT count() OVER (ORDER BY 3.4028234663852886e38 RANGE BETWEEN nan PRECEDING AND UNBOUNDED FOLLOWING);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x0000000033647a57 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:100: DB::WindowFrame::checkValid() const @ 0x0000000033646df0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2564: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303b14aa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3290: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037c521 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:55:04.050782 [ 15867 ] {} TCPHandler: Code: 36. DB::Exception: Frame start offset for 'RANGE' frame must be a nonnegative 32-bit integer, 'nan' of type 'Float64' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x0000000033647a57 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:100: DB::WindowFrame::checkValid() const @ 0x0000000033646df0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2564: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303b14aa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3290: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037c521 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:55:04.083018 [ 15867 ] {84e397f2-bd3b-4fa0-b1a7-1aabef5042b2} executeQuery: Code: 36. DB::Exception: Frame end offset for 'RANGE' frame must be a nonnegative 32-bit integer, '0.' of type 'Float64' given. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37734) (comment: 02833_window_func_range_offset.sql) (query 3, line 4) (in query: -- invalid end offset with RANGE SELECT count() OVER (ORDER BY 3.4028234663852886e38 RANGE BETWEEN UNBOUNDED PRECEDING AND 0.0 FOLLOWING);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x0000000033647a57 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:113: DB::WindowFrame::checkValid() const @ 0x0000000033647057 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2564: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303b14aa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3290: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037c521 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:55:04.089448 [ 15867 ] {} TCPHandler: Code: 36. DB::Exception: Frame end offset for 'RANGE' frame must be a nonnegative 32-bit integer, '0.' of type 'Float64' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x0000000033647a57 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:113: DB::WindowFrame::checkValid() const @ 0x0000000033647057 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2564: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303b14aa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3290: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037c521 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:55:04.114757 [ 15867 ] {d017bfd9-2a0e-4620-8849-a3cf79d48e65} executeQuery: Code: 36. DB::Exception: Frame end offset for 'RANGE' frame must be a nonnegative 32-bit integer, 'nan' of type 'Float64' given. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37734) (comment: 02833_window_func_range_offset.sql) (query 4, line 6) (in query: SELECT count() OVER (ORDER BY 3.4028234663852886e38 RANGE BETWEEN UNBOUNDED PRECEDING AND nan FOLLOWING);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x0000000033647a57 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:113: DB::WindowFrame::checkValid() const @ 0x0000000033647057 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2564: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303b14aa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3290: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037c521 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:55:04.119386 [ 15867 ] {} TCPHandler: Code: 36. DB::Exception: Frame end offset for 'RANGE' frame must be a nonnegative 32-bit integer, 'nan' of type 'Float64' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x0000000033647a57 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:113: DB::WindowFrame::checkValid() const @ 0x0000000033647057 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2564: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303b14aa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3290: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037c521 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:55:04.612757 [ 24872 ] {d1f20f75-661c-4059-9d9c-f5b19ae5a801} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 19.62 MiB (attempt to allocate chunk of 1.25 MiB bytes), maximum: 19.07 MiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37706) (comment: 01655_plan_optimizations_optimize_read_in_window_order_long.sh) (query 1, line 1) (in query: select n, sum(x) OVER (PARTITION BY n+x%2 ORDER BY n, x ROWS BETWEEN 100 PRECEDING AND CURRENT ROW) from test_01655_plan_optimizations_optimize_read_in_window_order_long_n_x SETTINGS optimize_read_in_order=1, max_memory_usage=20000000, max_threads=1 format Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f53cbed 8. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008ba58bc 9. ./build_docker/./src/Interpreters/sortBlock.cpp:163: DB::(anonymous namespace)::getBlockSortPermutationImpl(DB::Block const&, DB::SortDescription const&, DB::IColumn::PermutationSortStability, unsigned long, DB::PODArray, 63ul, 64ul>&) @ 0x00000000339089f3 10. ./build_docker/./src/Interpreters/sortBlock.cpp:339: DB::sortBlock(DB::Block&, DB::SortDescription const&, unsigned long) @ 0x00000000339079ea 11. ./build_docker/./src/Processors/Transforms/PartialSortingTransform.cpp:137: DB::PartialSortingTransform::transform(DB::Chunk&) @ 0x000000003babcdc5 12. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:55:04.634242 [ 24872 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 19.62 MiB (attempt to allocate chunk of 1.25 MiB bytes), maximum: 19.07 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f53cbed 8. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008ba58bc 9. ./build_docker/./src/Interpreters/sortBlock.cpp:163: DB::(anonymous namespace)::getBlockSortPermutationImpl(DB::Block const&, DB::SortDescription const&, DB::IColumn::PermutationSortStability, unsigned long, DB::PODArray, 63ul, 64ul>&) @ 0x00000000339089f3 10. ./build_docker/./src/Interpreters/sortBlock.cpp:339: DB::sortBlock(DB::Block&, DB::SortDescription const&, unsigned long) @ 0x00000000339079ea 11. ./build_docker/./src/Processors/Transforms/PartialSortingTransform.cpp:137: DB::PartialSortingTransform::transform(DB::Chunk&) @ 0x000000003babcdc5 12. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:55:07.715198 [ 15875 ] {b5f8cbfc-1554-4808-b8df-8f7b9610e515} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.02 GiB (attempt to allocate chunk of 128.00 MiB bytes), maximum: 953.67 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:34932) (comment: 01514_distributed_cancel_query_on_error.sh) (query 1, line 1) (in query: SELECT groupArray(repeat('a', if(shardNum() = 2, 100000, 1))) AS `groupArray(repeat('a', if(equals(_shard_num, 2), 100000, 1)))`, `__table1`.`number` % 100000 AS `k` FROM `system`.`numbers` AS `__table1` GROUP BY `__table1`.`number` % 100000 LIMIT _CAST(10000000, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f53cbed 8. DB::Arena::addMemoryChunk(unsigned long) @ 0x000000000b109eb8 9. DB::Arena::alignedAlloc(unsigned long, unsigned long) @ 0x000000000b109925 10. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:439: DB::IAggregateFunctionHelper>>::addBatch(unsigned long, unsigned long, char**, unsigned long, DB::IColumn const**, DB::Arena*, long) const @ 0x0000000020c0b261 11. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeAggregateInstructions(DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, std::unique_ptr> const&, unsigned long, bool, bool, bool) const @ 0x0000000031bca003 12. ./build_docker/./src/Interpreters/Aggregator.cpp:1191: void DB::Aggregator::executeImplBatch, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, false, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x000000003205ab9c 13. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, false, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x00000000320521cd 14. ./build_docker/./src/Interpreters/Aggregator.cpp:952: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x0000000031dae704 15. ./build_docker/./src/Interpreters/Aggregator.cpp:922: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x0000000031bc549b 16. ./build_docker/./src/Interpreters/Aggregator.cpp:1587: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031bd0b95 17. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003b9b97c5 18. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003b9ac388 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:55:08.027405 [ 15875 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.02 GiB (attempt to allocate chunk of 128.00 MiB bytes), maximum: 953.67 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f53cbed 8. DB::Arena::addMemoryChunk(unsigned long) @ 0x000000000b109eb8 9. DB::Arena::alignedAlloc(unsigned long, unsigned long) @ 0x000000000b109925 10. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:439: DB::IAggregateFunctionHelper>>::addBatch(unsigned long, unsigned long, char**, unsigned long, DB::IColumn const**, DB::Arena*, long) const @ 0x0000000020c0b261 11. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeAggregateInstructions(DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, std::unique_ptr> const&, unsigned long, bool, bool, bool) const @ 0x0000000031bca003 12. ./build_docker/./src/Interpreters/Aggregator.cpp:1191: void DB::Aggregator::executeImplBatch, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, false, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x000000003205ab9c 13. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, false, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x00000000320521cd 14. ./build_docker/./src/Interpreters/Aggregator.cpp:952: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x0000000031dae704 15. ./build_docker/./src/Interpreters/Aggregator.cpp:922: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x0000000031bc549b 16. ./build_docker/./src/Interpreters/Aggregator.cpp:1587: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031bd0b95 17. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003b9b97c5 18. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003b9ac388 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:55:08.085409 [ 9234 ] {fe030a1e-a3f8-44f8-b95d-dca8014d2a60} executeQuery: Code: 241. DB::Exception: Received from 127.3:9000. DB::Exception: Query memory limit exceeded: would use 1.02 GiB (attempt to allocate chunk of 128.00 MiB bytes), maximum: 953.67 MiB.: While executing AggregatingTransform. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f53cbed 8. DB::Arena::addMemoryChunk(unsigned long) @ 0x000000000b109eb8 9. DB::Arena::alignedAlloc(unsigned long, unsigned long) @ 0x000000000b109925 10. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:439: DB::IAggregateFunctionHelper>>::addBatch(unsigned long, unsigned long, char**, unsigned long, DB::IColumn const**, DB::Arena*, long) const @ 0x0000000020c0b261 11. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeAggregateInstructions(DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, std::unique_ptr> const&, unsigned long, bool, bool, bool) const @ 0x0000000031bca003 12. ./build_docker/./src/Interpreters/Aggregator.cpp:1191: void DB::Aggregator::executeImplBatch, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, false, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x000000003205ab9c 13. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, false, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x00000000320521cd 14. ./build_docker/./src/Interpreters/Aggregator.cpp:952: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x0000000031dae704 15. ./build_docker/./src/Interpreters/Aggregator.cpp:922: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x0000000031bc549b 16. ./build_docker/./src/Interpreters/Aggregator.cpp:1587: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031bd0b95 17. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003b9b97c5 18. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003b9ac388 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 : While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37708) (comment: 01514_distributed_cancel_query_on_error.sh) (query 1, line 1) (in query: SELECT groupArray(repeat('a', if(_shard_num == 2, 100000, 1))), number%100000 k from remote('127.{2,3}', system.numbers) GROUP BY k LIMIT 10e6), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f893977 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003a97bf4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003a99a03b 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aa95398 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 2025.06.13 08:55:08.106440 [ 9234 ] {} TCPHandler: Code: 241. DB::Exception: Received from 127.3:9000. DB::Exception: Query memory limit exceeded: would use 1.02 GiB (attempt to allocate chunk of 128.00 MiB bytes), maximum: 953.67 MiB.: While executing AggregatingTransform. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f53cbed 8. DB::Arena::addMemoryChunk(unsigned long) @ 0x000000000b109eb8 9. DB::Arena::alignedAlloc(unsigned long, unsigned long) @ 0x000000000b109925 10. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:439: DB::IAggregateFunctionHelper>>::addBatch(unsigned long, unsigned long, char**, unsigned long, DB::IColumn const**, DB::Arena*, long) const @ 0x0000000020c0b261 11. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeAggregateInstructions(DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, std::unique_ptr> const&, unsigned long, bool, bool, bool) const @ 0x0000000031bca003 12. ./build_docker/./src/Interpreters/Aggregator.cpp:1191: void DB::Aggregator::executeImplBatch, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, false, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x000000003205ab9c 13. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, false, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x00000000320521cd 14. ./build_docker/./src/Interpreters/Aggregator.cpp:952: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x0000000031dae704 15. ./build_docker/./src/Interpreters/Aggregator.cpp:922: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x0000000031bc549b 16. ./build_docker/./src/Interpreters/Aggregator.cpp:1587: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031bd0b95 17. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003b9b97c5 18. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003b9ac388 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 : While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f893977 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003a97bf4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003a99a03b 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aa95398 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f23cf19 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f23c285 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2399d2 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:55:08.233732 [ 9261 ] {c7de327c-c5dd-4e3f-9a41-d52667b1a1e8} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `x` in scope SELECT x FROM system.numbers LIMIT 1. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:45674) (comment: 02899_use_default_format_on_http_exception.sh) (in query: SELECT x FROM system.numbers LIMIT 1; ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000303dd3a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032b465 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 18. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 19. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 20. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:55:08.241304 [ 9261 ] {c7de327c-c5dd-4e3f-9a41-d52667b1a1e8} DynamicQueryHandler: Code: 47. DB::Exception: Unknown expression identifier `x` in scope SELECT x FROM system.numbers LIMIT 1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000303dd3a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032b465 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 18. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 19. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 20. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:55:08.430681 [ 15838 ] {2ba17c2a-e720-4781-9ca6-3c3d51f227e2} executeQuery: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:45686) (comment: 02899_use_default_format_on_http_exception.sh) (in query: INSERT INTO system.numbers Select * from numbers(10); ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003824c2e7 4. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003bc6ca76 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x00000000329cff8b 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x00000000329d5483 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000329db39d 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x00000000329e3a29 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:55:08.435447 [ 15838 ] {2ba17c2a-e720-4781-9ca6-3c3d51f227e2} DynamicQueryHandler: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003824c2e7 4. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003bc6ca76 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x00000000329cff8b 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x00000000329d5483 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000329db39d 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x00000000329e3a29 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:55:08.500832 [ 404 ] {aa97ab9a-8004-4547-8508-0aa8fd5eb5ff} executeQuery: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:45698) (comment: 02899_use_default_format_on_http_exception.sh) (in query: INSERT INTO system.numbers Select * from numbers(10); ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003824c2e7 4. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003bc6ca76 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x00000000329cff8b 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x00000000329d5483 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000329db39d 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x00000000329e3a29 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:55:08.507110 [ 404 ] {aa97ab9a-8004-4547-8508-0aa8fd5eb5ff} DynamicQueryHandler: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003824c2e7 4. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003bc6ca76 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x00000000329cff8b 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x00000000329d5483 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000329db39d 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x00000000329e3a29 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:55:08.566041 [ 404 ] {e51bcdbf-fcef-417e-90ed-88d5cd96eb5d} executeQuery: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:45714) (comment: 02899_use_default_format_on_http_exception.sh) (in query: INSERT INTO system.numbers Select * from numbers(10); ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003824c2e7 4. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003bc6ca76 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x00000000329cff8b 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x00000000329d5483 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000329db39d 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x00000000329e3a29 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:55:08.687339 [ 404 ] {e51bcdbf-fcef-417e-90ed-88d5cd96eb5d} executeQuery: Code: 73. DB::Exception: Unknown format BADFORMAT. (UNKNOWN_FORMAT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Formats/FormatFactory.cpp:75: DB::FormatFactory::getCreators(String const&) const @ 0x000000003ae7e66e 5. ./build_docker/./src/Formats/FormatFactory.cpp:590: DB::FormatFactory::getOutputFormat(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ae91ca4 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1728: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>)::$_1::operator()() const @ 0x000000003374dffc 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1767: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000337469fd 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 08:55:08.690183 [ 404 ] {e51bcdbf-fcef-417e-90ed-88d5cd96eb5d} DynamicQueryHandler: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003824c2e7 4. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003bc6ca76 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x00000000329cff8b 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x00000000329d5483 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000329db39d 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x00000000329e3a29 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:55:08.732101 [ 404 ] {0976b1af-d957-4868-8b8e-8b383a20fa47} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `x` in scope SELECT x FROM system.numbers LIMIT 1. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:45726) (comment: 02899_use_default_format_on_http_exception.sh) (in query: SELECT x FROM system.numbers LIMIT 1; ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000303dd3a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032b465 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 18. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 19. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 20. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:55:08.736426 [ 404 ] {0976b1af-d957-4868-8b8e-8b383a20fa47} DynamicQueryHandler: Code: 47. DB::Exception: Unknown expression identifier `x` in scope SELECT x FROM system.numbers LIMIT 1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000303dd3a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032b465 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 18. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 19. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 20. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:55:08.803429 [ 404 ] {831b38a9-b446-4f08-8bdf-2d77a8007f3e} executeQuery: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:45734) (comment: 02899_use_default_format_on_http_exception.sh) (in query: INSERT INTO system.numbers Select * from numbers(10); ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003824c2e7 4. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003bc6ca76 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x00000000329cff8b 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x00000000329d5483 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000329db39d 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x00000000329e3a29 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:55:08.808999 [ 404 ] {831b38a9-b446-4f08-8bdf-2d77a8007f3e} DynamicQueryHandler: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003824c2e7 4. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003bc6ca76 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x00000000329cff8b 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x00000000329d5483 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000329db39d 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x00000000329e3a29 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:55:08.867181 [ 24840 ] {c67b4330-42f9-49ab-8177-878df461d780} executeQuery: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:45740) (comment: 02899_use_default_format_on_http_exception.sh) (in query: INSERT INTO system.numbers Select * from numbers(10); ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003824c2e7 4. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003bc6ca76 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x00000000329cff8b 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x00000000329d5483 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000329db39d 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x00000000329e3a29 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:55:08.871707 [ 24840 ] {c67b4330-42f9-49ab-8177-878df461d780} DynamicQueryHandler: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003824c2e7 4. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003bc6ca76 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x00000000329cff8b 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x00000000329d5483 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000329db39d 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x00000000329e3a29 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:55:08.935987 [ 24843 ] {a2480b77-808d-45e9-828e-0b9a40896ec7} executeQuery: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:45748) (comment: 02899_use_default_format_on_http_exception.sh) (in query: INSERT INTO system.numbers Select * from numbers(10); ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003824c2e7 4. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003bc6ca76 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x00000000329cff8b 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x00000000329d5483 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000329db39d 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x00000000329e3a29 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:55:08.938049 [ 24843 ] {a2480b77-808d-45e9-828e-0b9a40896ec7} executeQuery: Code: 73. DB::Exception: Unknown format BADFORMAT. (UNKNOWN_FORMAT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Formats/FormatFactory.cpp:75: DB::FormatFactory::getCreators(String const&) const @ 0x000000003ae7e66e 5. ./build_docker/./src/Formats/FormatFactory.cpp:590: DB::FormatFactory::getOutputFormat(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ae91ca4 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1728: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>)::$_1::operator()() const @ 0x000000003374dffc 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1767: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000337469fd 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 08:55:08.941065 [ 24843 ] {a2480b77-808d-45e9-828e-0b9a40896ec7} DynamicQueryHandler: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003824c2e7 4. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003bc6ca76 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x00000000329cff8b 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x00000000329d5483 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000329db39d 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x00000000329e3a29 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:55:10.669328 [ 9261 ] {1782be80-c204-455d-a3e3-79562134b0bf} executeQuery: Code: 1. DB::Exception: Table expression modifiers SAMPLE 1 / 2 are not supported for subquery SELECT 1. (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37956) (comment: 02896_illegal_sampling.sql) (query 1, line 1) (in query: SELECT * FROM (SELECT 1) SAMPLE 1 / 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:903: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030281d4d 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003025ed8a 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003026a541 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003025ea82 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000003025d3c8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae30f2 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:55:10.673773 [ 9261 ] {} TCPHandler: Code: 1. DB::Exception: Table expression modifiers SAMPLE 1 / 2 are not supported for subquery SELECT 1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:903: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030281d4d 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003025ed8a 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003026a541 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003025ea82 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000003025d3c8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae30f2 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:55:19.057221 [ 9224 ] {78703ac4-62d9-4bb0-b3e5-9020c872b1e8} mysqlxx::Pool: Failed to connect to MySQL (conv_main@127.0.0.1:3456 as user metrika): mysqlxx::ConnectionFailed 2025.06.13 08:55:19.057817 [ 9224 ] {78703ac4-62d9-4bb0-b3e5-9020c872b1e8} Application: Connection to conv_main@127.0.0.1:3456 as user metrika failed: mysqlxx::ConnectionFailed: Can't connect to MySQL server on '127.0.0.1' (115) ((nullptr):0) 2025.06.13 08:55:19.058272 [ 9224 ] {78703ac4-62d9-4bb0-b3e5-9020c872b1e8} Application: Connection to mysql failed 1 times 2025.06.13 08:55:19.058949 [ 9224 ] {78703ac4-62d9-4bb0-b3e5-9020c872b1e8} mysqlxx::Pool: Failed to connect to MySQL (conv_main@127.0.0.1:3456 as user metrika): mysqlxx::ConnectionFailed 2025.06.13 08:55:19.059053 [ 9224 ] {78703ac4-62d9-4bb0-b3e5-9020c872b1e8} Application: Connection to conv_main@127.0.0.1:3456 as user metrika failed: mysqlxx::ConnectionFailed: Can't connect to MySQL server on '127.0.0.1' (115) ((nullptr):0) 2025.06.13 08:55:19.059093 [ 9224 ] {78703ac4-62d9-4bb0-b3e5-9020c872b1e8} Application: Connection to mysql failed 2 times 2025.06.13 08:55:19.059311 [ 9224 ] {78703ac4-62d9-4bb0-b3e5-9020c872b1e8} mysqlxx::Pool: Failed to connect to MySQL (conv_main@127.0.0.1:3456 as user metrika): mysqlxx::ConnectionFailed 2025.06.13 08:55:19.059417 [ 9224 ] {78703ac4-62d9-4bb0-b3e5-9020c872b1e8} Application: Connection to conv_main@127.0.0.1:3456 as user metrika failed: mysqlxx::ConnectionFailed: Can't connect to MySQL server on '127.0.0.1' (115) ((nullptr):0) 2025.06.13 08:55:19.059471 [ 9224 ] {78703ac4-62d9-4bb0-b3e5-9020c872b1e8} Application: Connection to mysql failed 3 times 2025.06.13 08:55:19.364522 [ 9224 ] {78703ac4-62d9-4bb0-b3e5-9020c872b1e8} executeQuery: Code: 501. DB::Exception: Cannot create MySQL database, because Code: 279. DB::Exception: Connections to mysql failed: conv_main@127.0.0.1:3456 as user metrika, ERROR 2002 : mysqlxx::ConnectionFailed: Can't connect to MySQL server on '127.0.0.1' (115) ((nullptr):0). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x00000000411788d4 5. ./build_docker/./src/Databases/MySQL/DatabaseMySQL.cpp:310: DB::DatabaseMySQL::fetchTablesWithModificationTime(std::shared_ptr) const @ 0x000000002fd01204 6. ./build_docker/./src/Databases/MySQL/DatabaseMySQL.cpp:228: DB::DatabaseMySQL::fetchTablesIntoLocalCache(std::shared_ptr) const @ 0x000000002fcfac12 7. ./build_docker/./src/Databases/MySQL/DatabaseMySQL.cpp:110: DB::DatabaseMySQL::empty() const @ 0x000000002fcf9a28 8. ./build_docker/./src/Databases/MySQL/DatabaseMySQL.cpp:92: DB::DatabaseMySQL::DatabaseMySQL(std::shared_ptr, String const&, String const&, DB::ASTStorage const*, String const&, std::unique_ptr>, mysqlxx::PoolWithFailover&&, bool) @ 0x000000002fcf8e42 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, String const&, String const&, DB::ASTStorage*&, String&, std::unique_ptr>, mysqlxx::PoolWithFailover, bool const&, 0>(std::allocator const&, std::shared_ptr&, String const&, String const&, DB::ASTStorage*&, String&, std::unique_ptr>&&, mysqlxx::PoolWithFailover&&, bool const&) @ 0x000000002fd17bfe 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x000000002fd10070 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f831acb 12. ./build_docker/./src/Databases/DatabaseFactory.cpp:111: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x000000002f8303c7 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:341: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000328bbd02 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3a0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)). (CANNOT_CREATE_DATABASE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33248) (comment: 01114_mysql_database_engine_segfault.sql) (query 2, line 4) (in query: CREATE DATABASE conv_main ENGINE = MySQL('127.0.0.1:3456', conv_main, 'metrika', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Databases/MySQL/DatabaseMySQL.cpp:597: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x000000002fd111dd 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f831acb 6. ./build_docker/./src/Databases/DatabaseFactory.cpp:111: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x000000002f8303c7 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:341: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000328bbd02 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3a0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:55:19.369012 [ 9224 ] {} TCPHandler: Code: 501. DB::Exception: Cannot create MySQL database, because Code: 279. DB::Exception: Connections to mysql failed: conv_main@127.0.0.1:3456 as user metrika, ERROR 2002 : mysqlxx::ConnectionFailed: Can't connect to MySQL server on '127.0.0.1' (115) ((nullptr):0). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x00000000411788d4 5. ./build_docker/./src/Databases/MySQL/DatabaseMySQL.cpp:310: DB::DatabaseMySQL::fetchTablesWithModificationTime(std::shared_ptr) const @ 0x000000002fd01204 6. ./build_docker/./src/Databases/MySQL/DatabaseMySQL.cpp:228: DB::DatabaseMySQL::fetchTablesIntoLocalCache(std::shared_ptr) const @ 0x000000002fcfac12 7. ./build_docker/./src/Databases/MySQL/DatabaseMySQL.cpp:110: DB::DatabaseMySQL::empty() const @ 0x000000002fcf9a28 8. ./build_docker/./src/Databases/MySQL/DatabaseMySQL.cpp:92: DB::DatabaseMySQL::DatabaseMySQL(std::shared_ptr, String const&, String const&, DB::ASTStorage const*, String const&, std::unique_ptr>, mysqlxx::PoolWithFailover&&, bool) @ 0x000000002fcf8e42 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, String const&, String const&, DB::ASTStorage*&, String&, std::unique_ptr>, mysqlxx::PoolWithFailover, bool const&, 0>(std::allocator const&, std::shared_ptr&, String const&, String const&, DB::ASTStorage*&, String&, std::unique_ptr>&&, mysqlxx::PoolWithFailover&&, bool const&) @ 0x000000002fd17bfe 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x000000002fd10070 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f831acb 12. ./build_docker/./src/Databases/DatabaseFactory.cpp:111: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x000000002f8303c7 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:341: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000328bbd02 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3a0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)). (CANNOT_CREATE_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Databases/MySQL/DatabaseMySQL.cpp:597: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x000000002fd111dd 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f831acb 6. ./build_docker/./src/Databases/DatabaseFactory.cpp:111: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x000000002f8303c7 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:341: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000328bbd02 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3a0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:55:20.583460 [ 24857 ] {9e7e50ac-4d99-4cc1-86b8-61e431e045a2} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'bitSlice'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT bitSlice(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33286) (comment: 03214_bitslice_argument_evaluation.sql) (query 1, line 1) (in query: -- { echo } -- No arguments passed SELECT bitSlice();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002c037417 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c030910 5. DB::FunctionBitSlice::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ca25407 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:55:20.587945 [ 24857 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'bitSlice'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT bitSlice(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002c037417 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c030910 5. DB::FunctionBitSlice::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ca25407 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:55:20.861624 [ 24857 ] {18b5bef3-04da-41bf-a9d3-602ad3343eab} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'bitSlice'. Expected: String, got: UInt8: In scope SELECT bitSlice(1, 1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33286) (comment: 03214_bitslice_argument_evaluation.sql) (query 2, line 4) (in query: -- Invalid 1st argument passed SELECT bitSlice(1, 1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c037e87 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c0312c1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c02fb7f 6. DB::FunctionBitSlice::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ca25407 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:55:20.866252 [ 24857 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'bitSlice'. Expected: String, got: UInt8: In scope SELECT bitSlice(1, 1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c037e87 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c0312c1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c02fb7f 6. DB::FunctionBitSlice::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ca25407 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:55:20.890761 [ 24857 ] {ced46eec-b7b1-4649-86b6-da259df5d6ae} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'offset' to function 'bitSlice'. Expected: (U)Int8/16/32/64 or Float, got: String: In scope SELECT bitSlice('Hello', 'World'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33286) (comment: 03214_bitslice_argument_evaluation.sql) (query 3, line 6) (in query: -- Valid 1st argument, invalid 2nd argument passed SELECT bitSlice('Hello', 'World');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c037e87 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c0312c1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c02fb7f 6. DB::FunctionBitSlice::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ca25407 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:55:20.895608 [ 24857 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'offset' to function 'bitSlice'. Expected: (U)Int8/16/32/64 or Float, got: String: In scope SELECT bitSlice('Hello', 'World'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c037e87 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c0312c1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c02fb7f 6. DB::FunctionBitSlice::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ca25407 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:55:21.171766 [ 24857 ] {f50ae58c-5c6c-4dfb-8754-9fcc0e5e948f} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'length' to function 'bitSlice'. Expected: (U)Int8/16/32/64 or Float, got: String: In scope SELECT bitSlice('Hello', 1, 'World'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33286) (comment: 03214_bitslice_argument_evaluation.sql) (query 4, line 8) (in query: -- Valid 1st argument & 2nd argument, invalid 3rd argument passed SELECT bitSlice('Hello', 1, 'World');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c037e87 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c0312c1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c02fbef 6. DB::FunctionBitSlice::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ca25407 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:55:21.176266 [ 24857 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'length' to function 'bitSlice'. Expected: (U)Int8/16/32/64 or Float, got: String: In scope SELECT bitSlice('Hello', 1, 'World'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c037e87 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c0312c1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c02fbef 6. DB::FunctionBitSlice::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ca25407 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:55:21.209583 [ 24857 ] {f555313a-225b-42ff-8ab2-4c5f94f916fc} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'bitSlice'. Expected 2 mandatory arguments and 1 optional argument, got 4 arguments: In scope SELECT bitSlice('Hello', 1, 1, 'World'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33286) (comment: 03214_bitslice_argument_evaluation.sql) (query 5, line 10) (in query: -- More arguments then expected SELECT bitSlice('Hello', 1, 1, 'World');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002c037417 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c030910 5. DB::FunctionBitSlice::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ca25407 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:55:21.215753 [ 24857 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'bitSlice'. Expected 2 mandatory arguments and 1 optional argument, got 4 arguments: In scope SELECT bitSlice('Hello', 1, 1, 'World'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002c037417 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c030910 5. DB::FunctionBitSlice::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ca25407 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:55:28.273334 [ 15856 ] {ff404386-359a-41f6-8547-72047e01f24f} executeQuery: Code: 36. DB::Exception: Variant type should have at least one nested type. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37176) (comment: 03276_empty_variant_type.sql) (query 2, line 2) (in query: create table test (v Variant()) engine=Variant();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/DataTypes/DataTypeVariant.cpp:47: DB::DataTypeVariant::DataTypeVariant(std::vector, std::allocator>> const&) @ 0x000000002f3261b4 5. std::shared_ptr std::allocate_shared[abi:ne190107], std::vector, std::allocator>>, 0>(std::allocator const&, std::vector, std::allocator>>&&) @ 0x000000002c1f8126 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(std::shared_ptr const&) @ 0x000000002f32b85a 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:ne190107] (*)(std::shared_ptr const&), std::shared_ptr (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x000000002f25a19a 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f297d11 9. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:78: DB::DataTypeFactory::get(std::shared_ptr const&) const @ 0x000000002f291fb7 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:569: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x00000000328cb5fc 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:625: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000328cd61e 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000328d60b9 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000328fff5d 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:55:28.277652 [ 15856 ] {} TCPHandler: Code: 36. DB::Exception: Variant type should have at least one nested type. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/DataTypes/DataTypeVariant.cpp:47: DB::DataTypeVariant::DataTypeVariant(std::vector, std::allocator>> const&) @ 0x000000002f3261b4 5. std::shared_ptr std::allocate_shared[abi:ne190107], std::vector, std::allocator>>, 0>(std::allocator const&, std::vector, std::allocator>>&&) @ 0x000000002c1f8126 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(std::shared_ptr const&) @ 0x000000002f32b85a 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:ne190107] (*)(std::shared_ptr const&), std::shared_ptr (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x000000002f25a19a 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f297d11 9. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:78: DB::DataTypeFactory::get(std::shared_ptr const&) const @ 0x000000002f291fb7 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:569: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x00000000328cb5fc 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:625: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000328cd61e 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000328d60b9 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000328fff5d 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:55:30.613716 [ 24842 ] {b88b4821-9436-4f49-8a61-c7b22936a8b1} executeQuery: Code: 321. DB::Exception: Value -2208988800 is out of bounds of type DateTime: In scope SELECT toDateTime(toDateTime64('1900-01-01 00:00:00.123', 3)). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37246) (comment: 02900_date_time_check_overflow.sql) (query 16, line 23) (in query: SELECT toDateTime(toDateTime64('1900-01-01 00:00:00.123', 3));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&) @ 0x000000001e2d4c4a 4. ./src/Functions/FunctionsConversion.h:183: void DB::Transformer>, false, unsigned int>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::TransformDateTime64> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x000000002cb97c6b 5. ./src/Functions/DateTimeTransforms.h:2287: COW::immutable_ptr DB::DateTimeTransformImpl>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::TransformDateTime64> const&) @ 0x000000002cb97223 6. ./src/Functions/FunctionsConversion.h:1311: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cb71442 7. ./src/Core/callOnTypeIndex.h:278: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c7ef6c3 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c836ef0 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c835be2 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 2025.06.13 08:55:30.618648 [ 24842 ] {} TCPHandler: Code: 321. DB::Exception: Value -2208988800 is out of bounds of type DateTime: In scope SELECT toDateTime(toDateTime64('1900-01-01 00:00:00.123', 3)). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&) @ 0x000000001e2d4c4a 4. ./src/Functions/FunctionsConversion.h:183: void DB::Transformer>, false, unsigned int>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::TransformDateTime64> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x000000002cb97c6b 5. ./src/Functions/DateTimeTransforms.h:2287: COW::immutable_ptr DB::DateTimeTransformImpl>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::TransformDateTime64> const&) @ 0x000000002cb97223 6. ./src/Functions/FunctionsConversion.h:1311: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cb71442 7. ./src/Core/callOnTypeIndex.h:278: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c7ef6c3 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c836ef0 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c835be2 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 2025.06.13 08:55:30.646742 [ 24842 ] {a556ffd1-acaf-4ad4-872d-439d564ec940} executeQuery: Code: 321. DB::Exception: Value 10413791999 is out of bounds of type DateTime: In scope SELECT toDateTime(toDateTime64('2299-12-31 23:59:59.999', 3)). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37246) (comment: 02900_date_time_check_overflow.sql) (query 17, line 24) (in query: SELECT toDateTime(toDateTime64('2299-12-31 23:59:59.999', 3));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&) @ 0x000000001e2d4c4a 4. ./src/Functions/FunctionsConversion.h:183: void DB::Transformer>, false, unsigned int>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::TransformDateTime64> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x000000002cb97c6b 5. ./src/Functions/DateTimeTransforms.h:2287: COW::immutable_ptr DB::DateTimeTransformImpl>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::TransformDateTime64> const&) @ 0x000000002cb97223 6. ./src/Functions/FunctionsConversion.h:1311: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cb71442 7. ./src/Core/callOnTypeIndex.h:278: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c7ef6c3 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c836ef0 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c835be2 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 2025.06.13 08:55:30.650007 [ 24842 ] {} TCPHandler: Code: 321. DB::Exception: Value 10413791999 is out of bounds of type DateTime: In scope SELECT toDateTime(toDateTime64('2299-12-31 23:59:59.999', 3)). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&) @ 0x000000001e2d4c4a 4. ./src/Functions/FunctionsConversion.h:183: void DB::Transformer>, false, unsigned int>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::TransformDateTime64> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x000000002cb97c6b 5. ./src/Functions/DateTimeTransforms.h:2287: COW::immutable_ptr DB::DateTimeTransformImpl>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::TransformDateTime64> const&) @ 0x000000002cb97223 6. ./src/Functions/FunctionsConversion.h:1311: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cb71442 7. ./src/Core/callOnTypeIndex.h:278: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c7ef6c3 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c836ef0 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c835be2 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 2025.06.13 08:55:31.070381 [ 24842 ] {c96155c7-29d0-45dc-9e76-e2d0535fc402} executeQuery: Code: 321. DB::Exception: Value -25567 is out of bounds of type DateTime: In scope SELECT toDateTime(toDate32('1900-01-01')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37246) (comment: 02900_date_time_check_overflow.sql) (query 18, line 25) (in query: SELECT toDateTime(toDate32('1900-01-01'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x000000001ff61b4a 4. ./src/Functions/FunctionsConversion.h:162: void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::detail::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x000000002cb949cf 5. ./src/Functions/DateTimeTransforms.h:2287: COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x000000002cb94063 6. ./src/Functions/FunctionsConversion.h:1183: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cb6faca 7. ./src/Core/callOnTypeIndex.h:276: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c7efe59 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c836ef0 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c835be2 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 2025.06.13 08:55:31.074395 [ 24842 ] {} TCPHandler: Code: 321. DB::Exception: Value -25567 is out of bounds of type DateTime: In scope SELECT toDateTime(toDate32('1900-01-01')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x000000001ff61b4a 4. ./src/Functions/FunctionsConversion.h:162: void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::detail::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x000000002cb949cf 5. ./src/Functions/DateTimeTransforms.h:2287: COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x000000002cb94063 6. ./src/Functions/FunctionsConversion.h:1183: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cb6faca 7. ./src/Core/callOnTypeIndex.h:276: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c7efe59 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c836ef0 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c835be2 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 2025.06.13 08:55:31.099846 [ 24842 ] {e38eaa80-263a-4084-9724-0bda08d28ab1} executeQuery: Code: 321. DB::Exception: Value 120529 is out of bounds of type DateTime: In scope SELECT toDateTime(toDate32('2299-12-31')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37246) (comment: 02900_date_time_check_overflow.sql) (query 19, line 26) (in query: SELECT toDateTime(toDate32('2299-12-31'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x000000001ff61b4a 4. ./src/Functions/FunctionsConversion.h:162: void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::detail::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x000000002cb949cf 5. ./src/Functions/DateTimeTransforms.h:2287: COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x000000002cb94063 6. ./src/Functions/FunctionsConversion.h:1183: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cb6faca 7. ./src/Core/callOnTypeIndex.h:276: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c7efe59 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c836ef0 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c835be2 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 2025.06.13 08:55:31.103889 [ 24842 ] {} TCPHandler: Code: 321. DB::Exception: Value 120529 is out of bounds of type DateTime: In scope SELECT toDateTime(toDate32('2299-12-31')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x000000001ff61b4a 4. ./src/Functions/FunctionsConversion.h:162: void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::detail::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x000000002cb949cf 5. ./src/Functions/DateTimeTransforms.h:2287: COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x000000002cb94063 6. ./src/Functions/FunctionsConversion.h:1183: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cb6faca 7. ./src/Core/callOnTypeIndex.h:276: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c7efe59 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c836ef0 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c835be2 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 2025.06.13 08:55:31.544119 [ 24842 ] {a7ad94a6-fead-41b6-8f50-9aa22596d464} executeQuery: Code: 321. DB::Exception: Day number 65535 is out of bounds of type DateTime: In scope SELECT toDateTime(toDate('2149-06-06')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37246) (comment: 02900_date_time_check_overflow.sql) (query 20, line 27) (in query: SELECT toDateTime(toDate('2149-06-06'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned short&) @ 0x000000001f5e088a 4. ./src/Functions/FunctionsConversion.h:141: void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::detail::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x000000002cb919f8 5. ./src/Functions/DateTimeTransforms.h:2287: COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x000000002cb91063 6. ./src/Functions/FunctionsConversion.h:1183: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cb6f04a 7. ./src/Core/callOnTypeIndex.h:275: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c7efc4d 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c836ef0 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c835be2 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 2025.06.13 08:55:31.549183 [ 24842 ] {} TCPHandler: Code: 321. DB::Exception: Day number 65535 is out of bounds of type DateTime: In scope SELECT toDateTime(toDate('2149-06-06')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned short&) @ 0x000000001f5e088a 4. ./src/Functions/FunctionsConversion.h:141: void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::detail::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x000000002cb919f8 5. ./src/Functions/DateTimeTransforms.h:2287: COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x000000002cb91063 6. ./src/Functions/FunctionsConversion.h:1183: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cb6f04a 7. ./src/Core/callOnTypeIndex.h:275: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c7efc4d 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c836ef0 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c835be2 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 2025.06.13 08:55:31.935454 [ 24842 ] {3867faae-3d45-4fe5-a78d-c0090e6a1042} executeQuery: Code: 321. DB::Exception: Value -2208988799 is out of bounds of type Date: In scope SELECT toDate(toDateTime64('1900-01-01 00:00:00.123', 3)). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37246) (comment: 02900_date_time_check_overflow.sql) (query 21, line 28) (in query: SELECT toDate(toDateTime64('1900-01-01 00:00:00.123', 3));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&) @ 0x000000001e2d4c4a 4. ./src/Functions/DateTimeTransforms.h:97: DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1>::execute(long, DateLUTImpl const&) @ 0x000000002cacb48b 5. ./src/Functions/DateTimeTransforms.h:82: COW::immutable_ptr DB::DateTimeTransformImpl>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::TransformDateTime64> const&) @ 0x000000002cacabd0 6. ./src/Functions/FunctionsConversion.h:1305: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002caa70a2 7. ./src/Core/callOnTypeIndex.h:278: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c7ee203 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c82e99d 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c82d8e2 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 2025.06.13 08:55:31.939460 [ 24842 ] {} TCPHandler: Code: 321. DB::Exception: Value -2208988799 is out of bounds of type Date: In scope SELECT toDate(toDateTime64('1900-01-01 00:00:00.123', 3)). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&) @ 0x000000001e2d4c4a 4. ./src/Functions/DateTimeTransforms.h:97: DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1>::execute(long, DateLUTImpl const&) @ 0x000000002cacb48b 5. ./src/Functions/DateTimeTransforms.h:82: COW::immutable_ptr DB::DateTimeTransformImpl>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::TransformDateTime64> const&) @ 0x000000002cacabd0 6. ./src/Functions/FunctionsConversion.h:1305: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002caa70a2 7. ./src/Core/callOnTypeIndex.h:278: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c7ee203 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c82e99d 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c82d8e2 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 2025.06.13 08:55:31.966501 [ 24842 ] {4403b30f-acc2-4936-b23f-d796128b8f5c} executeQuery: Code: 321. DB::Exception: Value 10413791999 is out of bounds of type Date: In scope SELECT toDate(toDateTime64('2299-12-31 23:59:59.999', 3)). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37246) (comment: 02900_date_time_check_overflow.sql) (query 22, line 29) (in query: SELECT toDate(toDateTime64('2299-12-31 23:59:59.999', 3));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&) @ 0x000000001e2d4c4a 4. ./src/Functions/DateTimeTransforms.h:97: DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1>::execute(long, DateLUTImpl const&) @ 0x000000002cacb48b 5. ./src/Functions/DateTimeTransforms.h:82: COW::immutable_ptr DB::DateTimeTransformImpl>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::TransformDateTime64> const&) @ 0x000000002cacabd0 6. ./src/Functions/FunctionsConversion.h:1305: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002caa70a2 7. ./src/Core/callOnTypeIndex.h:278: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c7ee203 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c82e99d 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c82d8e2 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 2025.06.13 08:55:31.970504 [ 24842 ] {} TCPHandler: Code: 321. DB::Exception: Value 10413791999 is out of bounds of type Date: In scope SELECT toDate(toDateTime64('2299-12-31 23:59:59.999', 3)). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&) @ 0x000000001e2d4c4a 4. ./src/Functions/DateTimeTransforms.h:97: DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1>::execute(long, DateLUTImpl const&) @ 0x000000002cacb48b 5. ./src/Functions/DateTimeTransforms.h:82: COW::immutable_ptr DB::DateTimeTransformImpl>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::TransformDateTime64> const&) @ 0x000000002cacabd0 6. ./src/Functions/FunctionsConversion.h:1305: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002caa70a2 7. ./src/Core/callOnTypeIndex.h:278: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c7ee203 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c82e99d 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c82d8e2 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 2025.06.13 08:55:32.387723 [ 24842 ] {2513a399-70a7-45fa-b70f-dcd70f7df935} executeQuery: Code: 321. DB::Exception: Value -25567 is out of bounds of type Date: In scope SELECT toDate(toDate32('1900-01-01')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37246) (comment: 02900_date_time_check_overflow.sql) (query 23, line 30) (in query: SELECT toDate(toDate32('1900-01-01'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x000000001ff61b4a 4. ./src/Functions/DateTimeTransforms.h:117: void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x000000002cac57bb 5. ./src/Functions/DateTimeTransforms.h:2296: COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x000000002cac4ece 6. ./src/Functions/FunctionsConversion.h:1170: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002caa544a 7. ./src/Core/callOnTypeIndex.h:276: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c7ee999 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c82e99d 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c82d8e2 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 2025.06.13 08:55:32.392534 [ 24842 ] {} TCPHandler: Code: 321. DB::Exception: Value -25567 is out of bounds of type Date: In scope SELECT toDate(toDate32('1900-01-01')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x000000001ff61b4a 4. ./src/Functions/DateTimeTransforms.h:117: void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x000000002cac57bb 5. ./src/Functions/DateTimeTransforms.h:2296: COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x000000002cac4ece 6. ./src/Functions/FunctionsConversion.h:1170: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002caa544a 7. ./src/Core/callOnTypeIndex.h:276: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c7ee999 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c82e99d 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c82d8e2 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 2025.06.13 08:55:32.418098 [ 24842 ] {c0438339-40f2-40af-b07f-f31aceb40047} executeQuery: Code: 321. DB::Exception: Value 120529 is out of bounds of type Date: In scope SELECT toDate(toDate32('2299-12-31')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37246) (comment: 02900_date_time_check_overflow.sql) (query 24, line 31) (in query: SELECT toDate(toDate32('2299-12-31'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x000000001ff61b4a 4. ./src/Functions/DateTimeTransforms.h:117: void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x000000002cac57bb 5. ./src/Functions/DateTimeTransforms.h:2296: COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x000000002cac4ece 6. ./src/Functions/FunctionsConversion.h:1170: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002caa544a 7. ./src/Core/callOnTypeIndex.h:276: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c7ee999 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c82e99d 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c82d8e2 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 2025.06.13 08:55:32.421990 [ 24842 ] {} TCPHandler: Code: 321. DB::Exception: Value 120529 is out of bounds of type Date: In scope SELECT toDate(toDate32('2299-12-31')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x000000001ff61b4a 4. ./src/Functions/DateTimeTransforms.h:117: void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x000000002cac57bb 5. ./src/Functions/DateTimeTransforms.h:2296: COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x000000002cac4ece 6. ./src/Functions/FunctionsConversion.h:1170: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002caa544a 7. ./src/Core/callOnTypeIndex.h:276: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c7ee999 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c82e99d 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c82d8e2 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 2025.06.13 08:55:35.059469 [ 24841 ] {53f7952c-6876-4bd2-b3d8-2f3ec2045c63} executeQuery: Code: 73. DB::Exception: Unknown format aaa: In scope SELECT formatRow('aaa', *) FROM numbers(3). (UNKNOWN_FORMAT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37272) (comment: 01420_format_row.gen.sql) (query 67, line 83) (in query: -- unknown format select formatRow('aaa', *) from numbers(3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Formats/FormatFactory.cpp:937: DB::FormatFactory::checkFormatName(String const&) const @ 0x000000003ae9b8e0 5. DB::(anonymous namespace)::FormatRowOverloadResolver::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x000000000ed78f95 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff983f 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 29. ? @ 0x00007f5206343ac3 30. ? @ 0x00007f52063d5850 2025.06.13 08:55:35.064751 [ 24841 ] {} TCPHandler: Code: 73. DB::Exception: Unknown format aaa: In scope SELECT formatRow('aaa', *) FROM numbers(3). (UNKNOWN_FORMAT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Formats/FormatFactory.cpp:937: DB::FormatFactory::checkFormatName(String const&) const @ 0x000000003ae9b8e0 5. DB::(anonymous namespace)::FormatRowOverloadResolver::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x000000000ed78f95 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff983f 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 29. ? @ 0x00007f5206343ac3 30. ? @ 0x00007f52063d5850 2025.06.13 08:55:40.252140 [ 24872 ] {8cb434d4-7e29-45e5-b3cd-40f41ee9bbec} executeQuery: Code: 117. DB::Exception: Incorrect data: Sign = -117 (must be 1 or -1). (INCORRECT_DATA) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48038) (comment: 01679_incorrect_data_on_insert_collapsing.sh) (query 1, line 1) (in query: INSERT INTO collapsing_merge_tree VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Processors/Merges/Algorithms/CollapsingSortedAlgorithm.cpp:222: DB::CollapsingSortedAlgorithm::merge() @ 0x000000003bd71bd9 5. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:464: DB::MergeTreeDataWriter::mergeBlock(DB::Block&&, DB::SortDescription, std::vector> const&, DB::PODArray, 63ul, 64ul>*&, DB::MergeTreeData::MergingParams const&) @ 0x0000000039b7d044 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:613: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039b83663 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039b7e7f7 8. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a46b83d 9. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b10197a 17. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003adbc219 18. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x000000003ad8e9f8 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:55:40.265191 [ 24872 ] {} TCPHandler: Code: 117. DB::Exception: Incorrect data: Sign = -117 (must be 1 or -1). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Processors/Merges/Algorithms/CollapsingSortedAlgorithm.cpp:222: DB::CollapsingSortedAlgorithm::merge() @ 0x000000003bd71bd9 5. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:464: DB::MergeTreeDataWriter::mergeBlock(DB::Block&&, DB::SortDescription, std::vector> const&, DB::PODArray, 63ul, 64ul>*&, DB::MergeTreeData::MergingParams const&) @ 0x0000000039b7d044 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:613: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039b83663 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039b7e7f7 8. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a46b83d 9. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b10197a 17. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003adbc219 18. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x000000003ad8e9f8 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:55:42.089810 [ 9261 ] {276ba02f-4df0-4230-9e67-ad025a4c5fed} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_table_for_01070_exception_code_in_query_log_table' in scope SELECT * FROM test_table_for_01070_exception_code_in_query_log_table. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48114) (comment: 01070_exception_code_in_query_log_table.sql) (query 2, line 2) (in query: SELECT * FROM test_table_for_01070_exception_code_in_query_log_table;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:55:42.096270 [ 9261 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_table_for_01070_exception_code_in_query_log_table' in scope SELECT * FROM test_table_for_01070_exception_code_in_query_log_table. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 08:55:46.632578 [ 1017 ] {} a2e7896c-24ee-4a03-943b-cbb221e8bc0d::all_1_1_0_2 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1 :: 3) -> throwIf(1) UInt8 : 5'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b0f6008 18. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1247: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039f9797c 19. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1162: DB::PartMergerWriter::execute() @ 0x000000003a003ab3 20. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1394: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ff2c32 21. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2113: DB::MutateTask::execute() @ 0x0000000039fa303f 22. ./src/Storages/MergeTree/MutateFromLogEntryTask.h:46: DB::MutateFromLogEntryTask::executeInnerTask() @ 0x0000000039f8e2c6 23. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:217: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1135ef 24. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:55:46.632585 [ 1015 ] {} a2e7896c-24ee-4a03-943b-cbb221e8bc0d::all_0_0_0_2 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1 :: 3) -> throwIf(1) UInt8 : 5'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b0f6008 18. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1247: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039f9797c 19. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1162: DB::PartMergerWriter::execute() @ 0x000000003a003ab3 20. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1394: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ff2c32 21. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2113: DB::MutateTask::execute() @ 0x0000000039fa303f 22. ./src/Storages/MergeTree/MutateFromLogEntryTask.h:46: DB::MutateFromLogEntryTask::executeInnerTask() @ 0x0000000039f8e2c6 23. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:217: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1135ef 24. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:55:46.635364 [ 1015 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a2e7896c-24ee-4a03-943b-cbb221e8bc0d::all_0_0_0_2}: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1 :: 3) -> throwIf(1) UInt8 : 5'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b0f6008 18. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1247: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039f9797c 19. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1162: DB::PartMergerWriter::execute() @ 0x000000003a003ab3 20. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1394: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ff2c32 21. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2113: DB::MutateTask::execute() @ 0x0000000039fa303f 22. ./src/Storages/MergeTree/MutateFromLogEntryTask.h:46: DB::MutateFromLogEntryTask::executeInnerTask() @ 0x0000000039f8e2c6 23. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:217: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1135ef 24. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:55:46.733123 [ 1017 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a2e7896c-24ee-4a03-943b-cbb221e8bc0d::all_1_1_0_2}: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1 :: 3) -> throwIf(1) UInt8 : 5'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b0f6008 18. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1247: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039f9797c 19. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1162: DB::PartMergerWriter::execute() @ 0x000000003a003ab3 20. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1394: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ff2c32 21. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2113: DB::MutateTask::execute() @ 0x0000000039fa303f 22. ./src/Storages/MergeTree/MutateFromLogEntryTask.h:46: DB::MutateFromLogEntryTask::executeInnerTask() @ 0x0000000039f8e2c6 23. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:217: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1135ef 24. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:55:46.931743 [ 24843 ] {836e8837-95c7-4f3a-bc54-b6087f6e554e} executeQuery: Code: 36. DB::Exception: Cannot drop column x because it's affected by mutation with ID '0000000001' which is not finished yet. Wait this mutation, or KILL it with command "KILL MUTATION WHERE mutation_id = '0000000001'". (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34772) (comment: 02597_column_update_and_replication.sql) (query 8, line 24) (in query: ALTER TABLE test DROP COLUMN x SETTINGS mutations_sync = 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::MergeTreeData::checkDropCommandDoesntAffectInProgressMutations(DB::AlterCommand const&, std::map, std::allocator>> const&, std::shared_ptr) const @ 0x000000003982bc6b 3. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3638: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003981bc22 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:55:46.942222 [ 24843 ] {} TCPHandler: Code: 36. DB::Exception: Cannot drop column x because it's affected by mutation with ID '0000000001' which is not finished yet. Wait this mutation, or KILL it with command "KILL MUTATION WHERE mutation_id = '0000000001'". (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::MergeTreeData::checkDropCommandDoesntAffectInProgressMutations(DB::AlterCommand const&, std::map, std::allocator>> const&, std::shared_ptr) const @ 0x000000003982bc6b 3. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3638: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003981bc22 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:55:47.795307 [ 1028 ] {} a2e7896c-24ee-4a03-943b-cbb221e8bc0d::all_1_1_0_2 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1 :: 3) -> throwIf(1) UInt8 : 5'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b0f6008 18. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1247: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039f9797c 19. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1162: DB::PartMergerWriter::execute() @ 0x000000003a003ab3 20. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1394: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ff2c32 21. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2113: DB::MutateTask::execute() @ 0x0000000039fa303f 22. ./src/Storages/MergeTree/MutateFromLogEntryTask.h:46: DB::MutateFromLogEntryTask::executeInnerTask() @ 0x0000000039f8e2c6 23. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:217: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1135ef 24. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:55:47.796958 [ 1028 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a2e7896c-24ee-4a03-943b-cbb221e8bc0d::all_1_1_0_2}: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1 :: 3) -> throwIf(1) UInt8 : 5'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b0f6008 18. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1247: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039f9797c 19. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1162: DB::PartMergerWriter::execute() @ 0x000000003a003ab3 20. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1394: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ff2c32 21. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2113: DB::MutateTask::execute() @ 0x0000000039fa303f 22. ./src/Storages/MergeTree/MutateFromLogEntryTask.h:46: DB::MutateFromLogEntryTask::executeInnerTask() @ 0x0000000039f8e2c6 23. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:217: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1135ef 24. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:55:47.859228 [ 1022 ] {} a2e7896c-24ee-4a03-943b-cbb221e8bc0d::all_0_0_0_2 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1 :: 3) -> throwIf(1) UInt8 : 5'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b0f6008 18. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1247: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039f9797c 19. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1162: DB::PartMergerWriter::execute() @ 0x000000003a003ab3 20. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1394: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ff2c32 21. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2113: DB::MutateTask::execute() @ 0x0000000039fa303f 22. ./src/Storages/MergeTree/MutateFromLogEntryTask.h:46: DB::MutateFromLogEntryTask::executeInnerTask() @ 0x0000000039f8e2c6 23. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:217: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1135ef 24. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:55:47.861715 [ 1022 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a2e7896c-24ee-4a03-943b-cbb221e8bc0d::all_0_0_0_2}: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1 :: 3) -> throwIf(1) UInt8 : 5'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b0f6008 18. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1247: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039f9797c 19. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1162: DB::PartMergerWriter::execute() @ 0x000000003a003ab3 20. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1394: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ff2c32 21. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2113: DB::MutateTask::execute() @ 0x0000000039fa303f 22. ./src/Storages/MergeTree/MutateFromLogEntryTask.h:46: DB::MutateFromLogEntryTask::executeInnerTask() @ 0x0000000039f8e2c6 23. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:217: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1135ef 24. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:55:48.413075 [ 1027 ] {} a2e7896c-24ee-4a03-943b-cbb221e8bc0d::all_0_0_0_2 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1 :: 3) -> throwIf(1) UInt8 : 5'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b0f6008 18. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1247: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039f9797c 19. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1162: DB::PartMergerWriter::execute() @ 0x000000003a003ab3 20. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1394: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ff2c32 21. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2113: DB::MutateTask::execute() @ 0x0000000039fa303f 22. ./src/Storages/MergeTree/MutateFromLogEntryTask.h:46: DB::MutateFromLogEntryTask::executeInnerTask() @ 0x0000000039f8e2c6 23. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:217: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1135ef 24. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:55:48.414640 [ 1027 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a2e7896c-24ee-4a03-943b-cbb221e8bc0d::all_0_0_0_2}: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1 :: 3) -> throwIf(1) UInt8 : 5'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b0f6008 18. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1247: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039f9797c 19. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1162: DB::PartMergerWriter::execute() @ 0x000000003a003ab3 20. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1394: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ff2c32 21. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2113: DB::MutateTask::execute() @ 0x0000000039fa303f 22. ./src/Storages/MergeTree/MutateFromLogEntryTask.h:46: DB::MutateFromLogEntryTask::executeInnerTask() @ 0x0000000039f8e2c6 23. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:217: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1135ef 24. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:55:48.477321 [ 1015 ] {} a2e7896c-24ee-4a03-943b-cbb221e8bc0d::all_1_1_0_2 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1 :: 3) -> throwIf(1) UInt8 : 5'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b0f6008 18. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1247: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039f9797c 19. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1162: DB::PartMergerWriter::execute() @ 0x000000003a003ab3 20. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1394: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ff2c32 21. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2113: DB::MutateTask::execute() @ 0x0000000039fa303f 22. ./src/Storages/MergeTree/MutateFromLogEntryTask.h:46: DB::MutateFromLogEntryTask::executeInnerTask() @ 0x0000000039f8e2c6 23. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:217: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1135ef 24. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:55:48.479441 [ 1015 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a2e7896c-24ee-4a03-943b-cbb221e8bc0d::all_1_1_0_2}: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1 :: 3) -> throwIf(1) UInt8 : 5'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b0f6008 18. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1247: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039f9797c 19. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1162: DB::PartMergerWriter::execute() @ 0x000000003a003ab3 20. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1394: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ff2c32 21. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2113: DB::MutateTask::execute() @ 0x0000000039fa303f 22. ./src/Storages/MergeTree/MutateFromLogEntryTask.h:46: DB::MutateFromLogEntryTask::executeInnerTask() @ 0x0000000039f8e2c6 23. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:217: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1135ef 24. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:55:49.363756 [ 1028 ] {} a2e7896c-24ee-4a03-943b-cbb221e8bc0d::all_1_1_0_2 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1 :: 3) -> throwIf(1) UInt8 : 5'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b0f6008 18. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1247: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039f9797c 19. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1162: DB::PartMergerWriter::execute() @ 0x000000003a003ab3 20. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1394: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ff2c32 21. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2113: DB::MutateTask::execute() @ 0x0000000039fa303f 22. ./src/Storages/MergeTree/MutateFromLogEntryTask.h:46: DB::MutateFromLogEntryTask::executeInnerTask() @ 0x0000000039f8e2c6 23. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:217: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1135ef 24. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:55:49.367025 [ 1028 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a2e7896c-24ee-4a03-943b-cbb221e8bc0d::all_1_1_0_2}: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1 :: 3) -> throwIf(1) UInt8 : 5'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b0f6008 18. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1247: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039f9797c 19. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1162: DB::PartMergerWriter::execute() @ 0x000000003a003ab3 20. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1394: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ff2c32 21. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2113: DB::MutateTask::execute() @ 0x0000000039fa303f 22. ./src/Storages/MergeTree/MutateFromLogEntryTask.h:46: DB::MutateFromLogEntryTask::executeInnerTask() @ 0x0000000039f8e2c6 23. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:217: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1135ef 24. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:55:49.580989 [ 1022 ] {} a2e7896c-24ee-4a03-943b-cbb221e8bc0d::all_0_0_0_2 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1 :: 3) -> throwIf(1) UInt8 : 5'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b0f6008 18. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1247: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039f9797c 19. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1162: DB::PartMergerWriter::execute() @ 0x000000003a003ab3 20. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1394: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ff2c32 21. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2113: DB::MutateTask::execute() @ 0x0000000039fa303f 22. ./src/Storages/MergeTree/MutateFromLogEntryTask.h:46: DB::MutateFromLogEntryTask::executeInnerTask() @ 0x0000000039f8e2c6 23. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:217: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1135ef 24. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:55:49.586937 [ 1022 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a2e7896c-24ee-4a03-943b-cbb221e8bc0d::all_0_0_0_2}: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1 :: 3) -> throwIf(1) UInt8 : 5'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b0f6008 18. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1247: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039f9797c 19. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1162: DB::PartMergerWriter::execute() @ 0x000000003a003ab3 20. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1394: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ff2c32 21. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2113: DB::MutateTask::execute() @ 0x0000000039fa303f 22. ./src/Storages/MergeTree/MutateFromLogEntryTask.h:46: DB::MutateFromLogEntryTask::executeInnerTask() @ 0x0000000039f8e2c6 23. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:217: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1135ef 24. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:55:49.621908 [ 34187 ] {a7d9159a-d274-439a-ab42-4307c67575e4} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 306. DB::Exception: JSON is too deep for key 'skipped_field'. (TOO_DEEP_RECURSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000115e1d0a 4. ./build_docker/./src/IO/ReadHelpers.cpp:1621: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc7df 5. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 6. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 7. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 8. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 9. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 10. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 11. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 12. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 13. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 14. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 15. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 16. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 18. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 19. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 20. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 21. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 22. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 23. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 24. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 25. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 26. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 27. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 28. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 29. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 30. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 31. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:293: DB::ParallelParsingInputFormat::scheduleParserThreadForUnitWithNumber(unsigned long) @ 0x000000003b5fec39 5. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:45: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x000000003b5fa53a 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x000000003b60654f 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b6061df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&) @ 0x000000003b60179d 5. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:158: DB::ParallelParsingInputFormat::read() @ 0x000000003b5fe482 6. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b108bd9 7. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 8. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b0f6008 14. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000266c3409 15. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d0326ad 16. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316edd5f 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030336f50 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 32. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 33. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 34. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 35. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 36. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 37. ? @ 0x00007f5206343ac3 38. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:55:49.763943 [ 9237 ] {a7d9159a-d274-439a-ab42-4307c67575e4} executeQuery: Code: 306. DB::Exception: JSON is too deep for key 'skipped_field': While executing ParallelParsingBlockInputFormat. (TOO_DEEP_RECURSION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34814) (comment: 03213_deep_json.sql) (query 1, line 1) (in query: -- The default limit works. SELECT * FROM format("JSONCompactEachRow", 'x UInt32, y UInt32', REPEAT('[1,1,', 100000)) SETTINGS input_format_json_compact_allow_variable_number_of_columns = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000115e1d0a 4. ./build_docker/./src/IO/ReadHelpers.cpp:1621: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc7df 5. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 6. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 7. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 8. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 9. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 10. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 11. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 12. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 13. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 14. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 15. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 16. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 18. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 19. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 20. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 21. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 22. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 23. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 24. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 25. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 26. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 27. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 28. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 29. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 30. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 31. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 2025.06.13 08:55:49.781050 [ 9237 ] {} TCPHandler: Code: 306. DB::Exception: JSON is too deep for key 'skipped_field': While executing ParallelParsingBlockInputFormat. (TOO_DEEP_RECURSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000115e1d0a 4. ./build_docker/./src/IO/ReadHelpers.cpp:1621: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc7df 5. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 6. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 7. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 8. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 9. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 10. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 11. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 12. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 13. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 14. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 15. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 16. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 18. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 19. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 20. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 21. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 22. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 23. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 24. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 25. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 26. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 27. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 28. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 29. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 30. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 31. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:293: DB::ParallelParsingInputFormat::scheduleParserThreadForUnitWithNumber(unsigned long) @ 0x000000003b5fec39 5. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:45: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x000000003b5fa53a 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x000000003b60654f 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b6061df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&) @ 0x000000003b60179d 5. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:158: DB::ParallelParsingInputFormat::read() @ 0x000000003b5fe482 6. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b108bd9 7. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 8. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b0f6008 14. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000266c3409 15. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d0326ad 16. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316edd5f 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030336f50 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 32. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 33. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 34. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 35. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 36. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 37. ? @ 0x00007f5206343ac3 38. ? @ 0x00007f52063d5850 2025.06.13 08:55:50.407761 [ 1028 ] {} a2e7896c-24ee-4a03-943b-cbb221e8bc0d::all_0_0_0_2 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1 :: 3) -> throwIf(1) UInt8 : 5'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b0f6008 18. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1247: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039f9797c 19. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1162: DB::PartMergerWriter::execute() @ 0x000000003a003ab3 20. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1394: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ff2c32 21. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2113: DB::MutateTask::execute() @ 0x0000000039fa303f 22. ./src/Storages/MergeTree/MutateFromLogEntryTask.h:46: DB::MutateFromLogEntryTask::executeInnerTask() @ 0x0000000039f8e2c6 23. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:217: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1135ef 24. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:55:50.411446 [ 1028 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a2e7896c-24ee-4a03-943b-cbb221e8bc0d::all_0_0_0_2}: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1 :: 3) -> throwIf(1) UInt8 : 5'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b0f6008 18. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1247: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039f9797c 19. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1162: DB::PartMergerWriter::execute() @ 0x000000003a003ab3 20. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1394: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ff2c32 21. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2113: DB::MutateTask::execute() @ 0x0000000039fa303f 22. ./src/Storages/MergeTree/MutateFromLogEntryTask.h:46: DB::MutateFromLogEntryTask::executeInnerTask() @ 0x0000000039f8e2c6 23. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:217: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1135ef 24. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:55:50.446758 [ 1015 ] {} a2e7896c-24ee-4a03-943b-cbb221e8bc0d::all_1_1_0_2 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1 :: 3) -> throwIf(1) UInt8 : 5'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b0f6008 18. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1247: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039f9797c 19. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1162: DB::PartMergerWriter::execute() @ 0x000000003a003ab3 20. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1394: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ff2c32 21. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2113: DB::MutateTask::execute() @ 0x0000000039fa303f 22. ./src/Storages/MergeTree/MutateFromLogEntryTask.h:46: DB::MutateFromLogEntryTask::executeInnerTask() @ 0x0000000039f8e2c6 23. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:217: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1135ef 24. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:55:50.448594 [ 1015 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a2e7896c-24ee-4a03-943b-cbb221e8bc0d::all_1_1_0_2}: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1 :: 3) -> throwIf(1) UInt8 : 5'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b0f6008 18. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1247: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039f9797c 19. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1162: DB::PartMergerWriter::execute() @ 0x000000003a003ab3 20. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1394: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ff2c32 21. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2113: DB::MutateTask::execute() @ 0x0000000039fa303f 22. ./src/Storages/MergeTree/MutateFromLogEntryTask.h:46: DB::MutateFromLogEntryTask::executeInnerTask() @ 0x0000000039f8e2c6 23. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:217: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1135ef 24. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:55:50.648499 [ 1028 ] {} test_p52tpldu.test (ReplicatedMergeTreeQueue): Mutation with version 2 not found in partition ID all (trying to mutate part all_0_0_0) 2025.06.13 08:55:50.652828 [ 1019 ] {} test_p52tpldu.test (ReplicatedMergeTreeQueue): Mutation with version 2 not found in partition ID all (trying to mutate part all_1_1_0) 2025.06.13 08:55:52.788864 [ 34293 ] {94ddd43d-6bbd-45c4-9057-b2e711a80971} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 306. DB::Exception: Stack size too large. Stack address: 0x7f4c5ca65000, frame address: 0x7f4c5cdda150, stack size: 4763312, maximum stack size: 8388608. (TOO_DEEP_RECURSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, void*&, void const*&, unsigned long&, unsigned long&) @ 0x000000001f84489f 4. ./build_docker/./src/Common/checkStackSize.cpp:151: checkStackSize() @ 0x000000001f8443c9 5. ./build_docker/./src/IO/ReadHelpers.cpp:1626: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc81e 6. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 7. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 8. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 9. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 10. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 11. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 12. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 13. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 14. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 15. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 16. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 18. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 19. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 20. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 21. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 22. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 23. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 24. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 25. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 26. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 27. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 28. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 29. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 30. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 31. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:293: DB::ParallelParsingInputFormat::scheduleParserThreadForUnitWithNumber(unsigned long) @ 0x000000003b5fec39 5. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:45: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x000000003b5fa53a 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x000000003b60654f 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b6061df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&) @ 0x000000003b60179d 5. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:158: DB::ParallelParsingInputFormat::read() @ 0x000000003b5fe482 6. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b108bd9 7. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 8. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b0f6008 14. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000266c3409 15. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d0326ad 16. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316edd5f 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030336f50 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 32. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 33. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 34. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 35. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 36. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 37. ? @ 0x00007f5206343ac3 38. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:55:52.817290 [ 9237 ] {94ddd43d-6bbd-45c4-9057-b2e711a80971} executeQuery: Code: 306. DB::Exception: Stack size too large. Stack address: 0x7f4c5ca65000, frame address: 0x7f4c5cdda150, stack size: 4763312, maximum stack size: 8388608: While executing ParallelParsingBlockInputFormat. (TOO_DEEP_RECURSION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34814) (comment: 03213_deep_json.sql) (query 3, line 5) (in query: SELECT * FROM format("JSONCompactEachRow", 'x UInt32, y UInt32', REPEAT('[1,1,', 100000)) SETTINGS input_format_json_compact_allow_variable_number_of_columns = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, void*&, void const*&, unsigned long&, unsigned long&) @ 0x000000001f84489f 4. ./build_docker/./src/Common/checkStackSize.cpp:151: checkStackSize() @ 0x000000001f8443c9 5. ./build_docker/./src/IO/ReadHelpers.cpp:1626: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc81e 6. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 7. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 8. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 9. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 10. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 11. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 12. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 13. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 14. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 15. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 16. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 18. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 19. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 20. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 21. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 22. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 23. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 24. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 25. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 26. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 27. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 28. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 29. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 30. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 31. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 2025.06.13 08:55:52.825809 [ 9237 ] {} TCPHandler: Code: 306. DB::Exception: Stack size too large. Stack address: 0x7f4c5ca65000, frame address: 0x7f4c5cdda150, stack size: 4763312, maximum stack size: 8388608: While executing ParallelParsingBlockInputFormat. (TOO_DEEP_RECURSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, void*&, void const*&, unsigned long&, unsigned long&) @ 0x000000001f84489f 4. ./build_docker/./src/Common/checkStackSize.cpp:151: checkStackSize() @ 0x000000001f8443c9 5. ./build_docker/./src/IO/ReadHelpers.cpp:1626: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc81e 6. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 7. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 8. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 9. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 10. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 11. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 12. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 13. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 14. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 15. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 16. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 18. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 19. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 20. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 21. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 22. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 23. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 24. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 25. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 26. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 27. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 28. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 29. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 30. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a 31. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001f8dc38a Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:293: DB::ParallelParsingInputFormat::scheduleParserThreadForUnitWithNumber(unsigned long) @ 0x000000003b5fec39 5. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:45: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x000000003b5fa53a 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x000000003b60654f 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b6061df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&) @ 0x000000003b60179d 5. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:158: DB::ParallelParsingInputFormat::read() @ 0x000000003b5fe482 6. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b108bd9 7. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 8. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b0f6008 14. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000266c3409 15. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d0326ad 16. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316edd5f 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030336f50 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 32. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 33. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 34. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 35. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 36. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 37. ? @ 0x00007f5206343ac3 38. ? @ 0x00007f52063d5850 2025.06.13 08:55:55.612063 [ 24844 ] {77ba45c7-7e23-4e6d-b378-d800b271d785} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositions doesn't match: passed 256, should be at most 255. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33048) (comment: 02364_multiSearch_function_family.sql) (query 380, line 520) (in query: select multiSearchAllPositions(materialize('string'), ['o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'str']);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, unsigned long&&) @ 0x0000000016ba1a8d 4. DB::FunctionsMultiStringPosition>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016ba033a 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301087b6 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000030104ffd 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003ba0ea77 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003bfff312 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032b1845f 15. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x0000000032b01504 16. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:55:55.627858 [ 24844 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositions doesn't match: passed 256, should be at most 255. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, unsigned long&&) @ 0x0000000016ba1a8d 4. DB::FunctionsMultiStringPosition>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016ba033a 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301087b6 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000030104ffd 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003ba0ea77 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003bfff312 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032b1845f 15. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x0000000032b01504 16. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:55:55.997958 [ 24844 ] {55f3de14-045f-41bb-a656-cb746af73ab3} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndex doesn't match: passed 256, should be at most 255. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33048) (comment: 02364_multiSearch_function_family.sql) (query 381, line 530) (in query: select multiSearchFirstIndex(materialize('string'), ['o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'str']);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const* const&, String&&, String&&) @ 0x000000000e5147d7 4. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016be7b4d 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301087b6 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000030104ffd 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003ba0ea77 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003bfff312 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032b1845f 15. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x0000000032b01504 16. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:55:56.027565 [ 24844 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndex doesn't match: passed 256, should be at most 255. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const* const&, String&&, String&&) @ 0x000000000e5147d7 4. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016be7b4d 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301087b6 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000030104ffd 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003ba0ea77 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003bfff312 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032b1845f 15. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x0000000032b01504 16. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:55:56.180592 [ 9220 ] {e22f61bf-baee-41ee-bb50-62fdd00802fe} executeQuery: Code: 386. DB::Exception: There is no supertype for types UInt64, Int8 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: In scope SELECT toTypeName([-1, toUInt64(1)]). (NO_COMMON_TYPE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50736) (comment: 01579_date_datetime_index_comparison.sql) (query 7, line 12) (in query: -- We don't promote to wide integers select toTypeName([-1, toUInt64(1)]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x000000002f49b5a2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:140: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002f499be2 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:688: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f4a5096 6. DB::FunctionArray::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b1b0dbe 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 8. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7eb0 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 2025.06.13 08:55:56.190436 [ 9220 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types UInt64, Int8 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: In scope SELECT toTypeName([-1, toUInt64(1)]). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x000000002f49b5a2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:140: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002f499be2 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:688: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f4a5096 6. DB::FunctionArray::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b1b0dbe 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 8. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7eb0 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 2025.06.13 08:55:58.900502 [ 9260 ] {80ccde81-fa64-4415-950b-01e5d1b984a8} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'max_substrings' to function 'splitByChar'. Expected: const Number, got: String: In scope SELECT splitByChar(',', '1,2,3', ''). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50842) (comment: 02475_split_with_max_substrings.sql) (query 2, line 2) (in query: SELECT splitByChar(',', '1,2,3', '');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c037e87 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c0312c1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c02fbef 6. DB::FunctionTokens::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a5478ee 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:55:58.906068 [ 9260 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'max_substrings' to function 'splitByChar'. Expected: const Number, got: String: In scope SELECT splitByChar(',', '1,2,3', ''). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c037e87 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c0312c1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c02fbef 6. DB::FunctionTokens::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a5478ee 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:55:59.276828 [ 9260 ] {c808f482-59d7-4b17-8d7c-869c903dabaf} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'max_substrings' to function 'splitByRegexp'. Expected: const Number, got: String: In scope SELECT splitByRegexp('[ABC]', 'oneAtwoBthreeC', ''). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50842) (comment: 02475_split_with_max_substrings.sql) (query 3, line 3) (in query: SELECT splitByRegexp('[ABC]', 'oneAtwoBthreeC', '');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c037e87 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c0312c1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c02fbef 6. DB::FunctionTokens::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a554d4e 7. DB::(anonymous namespace)::SplitByRegexpOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a54fb1f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:55:59.284326 [ 9260 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'max_substrings' to function 'splitByRegexp'. Expected: const Number, got: String: In scope SELECT splitByRegexp('[ABC]', 'oneAtwoBthreeC', ''). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c037e87 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c0312c1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c02fbef 6. DB::FunctionTokens::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a554d4e 7. DB::(anonymous namespace)::SplitByRegexpOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a54fb1f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:55:59.653130 [ 9260 ] {f54d2b18-527c-4f2f-a750-68ed86631233} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'max_substrings' to function 'alphaTokens'. Expected: const Number, got: String: In scope SELECT alphaTokens('abca1abc', ''). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50842) (comment: 02475_split_with_max_substrings.sql) (query 4, line 4) (in query: SELECT alphaTokens('abca1abc', '');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c037e87 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c0312c1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c02fbef 6. DB::FunctionTokens::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b12296e 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:55:59.658453 [ 9260 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'max_substrings' to function 'alphaTokens'. Expected: const Number, got: String: In scope SELECT alphaTokens('abca1abc', ''). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c037e87 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c0312c1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c02fbef 6. DB::FunctionTokens::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b12296e 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:55:59.686214 [ 9260 ] {17f7cf94-6b64-43d3-9325-84137e8cec6f} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'max_substrings' to function 'alphaTokens'. Expected: const Number, got: String: In scope SELECT splitByAlpha('abca1abc', ''). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50842) (comment: 02475_split_with_max_substrings.sql) (query 5, line 5) (in query: SELECT splitByAlpha('abca1abc', '');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c037e87 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c0312c1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c02fbef 6. DB::FunctionTokens::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b12296e 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:55:59.692897 [ 9260 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'max_substrings' to function 'alphaTokens'. Expected: const Number, got: String: In scope SELECT splitByAlpha('abca1abc', ''). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c037e87 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c0312c1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c02fbef 6. DB::FunctionTokens::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b12296e 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:56:00.022945 [ 9260 ] {96371985-1053-48f9-9125-46bfcabeb338} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'max_substrings' to function 'splitByNonAlpha'. Expected: const Number, got: String: In scope SELECT splitByNonAlpha(' 1! a, b. ', ''). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50842) (comment: 02475_split_with_max_substrings.sql) (query 6, line 6) (in query: SELECT splitByNonAlpha(' 1! a, b. ', '');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c037e87 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c0312c1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c02fbef 6. DB::FunctionTokens::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a54c22e 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:56:00.034731 [ 9260 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'max_substrings' to function 'splitByNonAlpha'. Expected: const Number, got: String: In scope SELECT splitByNonAlpha(' 1! a, b. ', ''). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c037e87 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c0312c1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c02fbef 6. DB::FunctionTokens::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a54c22e 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:56:00.371145 [ 9260 ] {d2e80dd5-6c2f-4f60-b2f7-fbbb77e7bcff} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'max_substrings' to function 'splitByWhitespace'. Expected: const Number, got: String: In scope SELECT splitByWhitespace(' 1! a, b. ', ''). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50842) (comment: 02475_split_with_max_substrings.sql) (query 7, line 7) (in query: SELECT splitByWhitespace(' 1! a, b. ', '');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c037e87 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c0312c1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c02fbef 6. DB::FunctionTokens::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a55f4ee 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:56:00.400966 [ 9260 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'max_substrings' to function 'splitByWhitespace'. Expected: const Number, got: String: In scope SELECT splitByWhitespace(' 1! a, b. ', ''). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c037e87 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c0312c1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c02fbef 6. DB::FunctionTokens::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a55f4ee 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:56:00.739370 [ 9260 ] {17ea809e-8ec2-4086-a799-b1ce3b378dfb} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'max_substrings' to function 'splitByString'. Expected: const Number, got: String: In scope SELECT splitByString(', ', '1, 2 3, 4,5, abcde', ''). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50842) (comment: 02475_split_with_max_substrings.sql) (query 8, line 8) (in query: SELECT splitByString(', ', '1, 2 3, 4,5, abcde', '');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c037e87 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c0312c1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c02fbef 6. DB::FunctionTokens::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a55ab6e 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:56:00.743746 [ 9260 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'max_substrings' to function 'splitByString'. Expected: const Number, got: String: In scope SELECT splitByString(', ', '1, 2 3, 4,5, abcde', ''). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c037e87 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c0312c1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c02fbef 6. DB::FunctionTokens::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a55ab6e 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:56:04.737768 [ 15856 ] {38fd9bbb-4a8c-49a0-9a80-ec081260b553} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:53668) (comment: 02835_drop_user_during_session.sh) (in query: SELECT COUNT(*) FROM system.numbers), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032e79999 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032e796c3 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032e7ac23 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b0aef87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae681 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:56:04.743613 [ 24860 ] {8cf09d45-6c5e-4128-9d55-f0ff4778ea38} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50936) (comment: 02835_drop_user_during_session.sh) (query 1, line 1) (in query: SELECT COUNT(*) FROM system.numbers), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032e79999 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032e796c3 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032e7ac23 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b0aef87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae681 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 08:56:04.746041 [ 2136 ] {41a870f4-caf1-4326-ab31-3415cb6c889c} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:53670) (comment: 02835_drop_user_during_session.sh) (in query: SELECT COUNT(*) FROM system.numbers), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032e79999 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032e796c3 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032e7ac23 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b0aef87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae681 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:56:04.761854 [ 24860 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032e79999 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032e796c3 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032e7ac23 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b0aef87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae681 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:56:04.762775 [ 15856 ] {38fd9bbb-4a8c-49a0-9a80-ec081260b553} DynamicQueryHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032e79999 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032e796c3 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032e7ac23 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b0aef87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae681 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:56:04.781682 [ 2136 ] {41a870f4-caf1-4326-ab31-3415cb6c889c} DynamicQueryHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032e79999 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032e796c3 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032e7ac23 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b0aef87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae681 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:56:09.379580 [ 404 ] {64f8dd21-100b-4903-950a-d203102a2b6b} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:44532) (comment: 02835_drop_user_during_session.sh) (in query: SELECT COUNT(*) FROM system.numbers), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032e79999 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032e796c3 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032e7ac23 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b0aef87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae681 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:56:09.380228 [ 24858 ] {76430d12-4e3f-41a2-9cb9-518e2f450d99} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:44522) (comment: 02835_drop_user_during_session.sh) (in query: SELECT COUNT(*) FROM system.numbers), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032e79999 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032e796c3 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032e7ac23 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b0aef87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae681 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:56:09.391347 [ 24858 ] {76430d12-4e3f-41a2-9cb9-518e2f450d99} DynamicQueryHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032e79999 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032e796c3 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032e7ac23 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b0aef87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae681 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:56:09.400131 [ 404 ] {64f8dd21-100b-4903-950a-d203102a2b6b} DynamicQueryHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032e79999 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032e796c3 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032e7ac23 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b0aef87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae681 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:56:09.407887 [ 24864 ] {1b6e044d-0cb8-4bad-8981-a0557388bbec} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50772) (comment: 02835_drop_user_during_session.sh) (query 1, line 1) (in query: SELECT COUNT(*) FROM system.numbers), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032e79999 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032e796c3 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032e7ac23 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b0aef87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae681 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 08:56:09.445321 [ 24864 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032e79999 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032e796c3 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032e7ac23 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b0aef87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae681 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:56:12.022548 [ 410 ] {} CgroupsReader: Cannot find 'kernel' in '/sys/fs/cgroup/memory.stat' (skipped 5923 similar messages) 2025.06.13 08:56:13.999546 [ 24861 ] {e5c4063b-03f2-4aa6-bc1e-1165a3ff520a} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50960) (comment: 02835_drop_user_during_session.sh) (query 1, line 1) (in query: SELECT COUNT(*) FROM system.numbers), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032e79999 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032e796c3 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032e7ac23 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b0aef87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae681 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 08:56:14.035866 [ 15860 ] {2ee320b3-ee16-45d5-900f-694fb4782975} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:44558) (comment: 02835_drop_user_during_session.sh) (in query: SELECT COUNT(*) FROM system.numbers), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032e79999 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032e796c3 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032e7ac23 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b0aef87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae681 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:56:14.043104 [ 24861 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032e79999 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032e796c3 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032e7ac23 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b0aef87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae681 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:56:14.048070 [ 24843 ] {1551570f-aea0-4cb9-b8fa-c9abea0acb6c} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:44546) (comment: 02835_drop_user_during_session.sh) (in query: SELECT COUNT(*) FROM system.numbers), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032e79999 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032e796c3 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032e7ac23 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b0aef87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae681 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:56:14.051316 [ 15860 ] {2ee320b3-ee16-45d5-900f-694fb4782975} DynamicQueryHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032e79999 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032e796c3 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032e7ac23 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b0aef87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae681 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:56:14.056927 [ 24843 ] {1551570f-aea0-4cb9-b8fa-c9abea0acb6c} DynamicQueryHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032e79999 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032e796c3 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032e7ac23 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b0aef87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae681 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aabf3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374446b 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:56:19.660685 [ 34132 ] {e919f27e-386b-4c1b-bf26-9f0090ea6830} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 117. DB::Exception: Duplicate field found while parsing BSONEachRow format: SilverlightVersion2: (at row 1) . (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x0000000008e1c4ca 4. ./build_docker/./src/Processors/Formats/Impl/BSONEachRowRowInputFormat.cpp:806: DB::BSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b2b6ab7 5. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b274d5f 6. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b108bd9 7. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 8. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 9. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000003b5ffbe5 10. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:95: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000003b5fbe27 11. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b6027bc 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:293: DB::ParallelParsingInputFormat::scheduleParserThreadForUnitWithNumber(unsigned long) @ 0x000000003b5fec39 5. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:45: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x000000003b5fa53a 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x000000003b60654f 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b6061df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&) @ 0x000000003b60179d 5. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:158: DB::ParallelParsingInputFormat::read() @ 0x000000003b5fe482 6. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b108bd9 7. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 8. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b0f6008 14. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000266c3409 15. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d0326ad 16. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316edd5f 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030336f50 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 32. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 33. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 34. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 35. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 36. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 37. ? @ 0x00007f5206343ac3 38. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:56:19.676395 [ 24842 ] {e919f27e-386b-4c1b-bf26-9f0090ea6830} executeQuery: Code: 117. DB::Exception: Duplicate field found while parsing BSONEachRow format: SilverlightVersion2: (at row 1) : While executing ParallelParsingBlockInputFormat. (INCORRECT_DATA) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42112) (comment: 02685_bson2.sql) (query 1, line 1) (in query: -- It correctly throws exception about incorrect data: SELECT * FROM format('BSONEachRow', 'WatchID Int64, JavaEnable Int16, Title String, GoodEvent Int16, EventTime DateTime, EventDate Date, CounterID Int32, ClientIP Int32, RegionID Int32, UserID Int64, CounterClass Int16, OS Int16, UserAgent Int16, URL String, Referer String, IsRefresh Int16, RefererCategoryID Int16, RefererRegionID Int32, URLCategoryID Int16, URLRegionID Int32, ResolutionWidth Int16, ResolutionHeight Int16, ResolutionDepth Int16, FlashMajor Int16, FlashMinor Int16, FlashMinor2 String, NetMajor Int16, NetMinor Int16, UserAgentMajor Int16, UserAgentMinor String, CookieEnable Int16, JavascriptEnable Int16, IsMobile Int16, MobilePhone Int16, MobilePhoneModel String, Params String, IPNetworkID Int32, TraficSourceID Int16, SearchEngineID Int16, SearchPhrase String, AdvEngineID Int16, IsArtifical Int16, WindowClientWidth Int16, WindowClientHeight Int16, ClientTimeZone Int16, ClientEventTime DateTime, SilverlightVersion1 Int16, SilverlightVersion2 Int16, SilverlightVersion3 Int32, SilverlightVersion4 Int16, PageCharset String, CodeVersion Int32, IsLink Int16, IsDownload Int16, IsNotBounce Int16, FUniqID Int64, OriginalURL String, HID Int32, IsOldCounter Int16, IsEvent Int16, IsParameter Int16, DontCountHits Int16, WithHash Int16, HitColor String, LocalEventTime DateTime, Age Int16, Sex Int16, Income Int16, Interests Int16, Robotness Int16, RemoteIP Int32, WindowName Int32, OpenerName Int32, HistoryLength Int16, BrowserLanguage String, BrowserCountry String, SocialNetwork String, SocialAction String, HTTPError Int16, SendTiming Int32, DNSTiming Int32, ConnectTiming Int32, ResponseStartTiming Int32, ResponseEndTiming Int32, FetchTiming Int32, SocialSourceNetworkID Int16, SocialSourcePage String, ParamPrice Int64, ParamOrderID String, ParamCurrency String, ParamCurrencyID Int16, OpenstatServiceName String, OpenstatCampaignID String, OpenstatAdID String, OpenstatSourceID String, UTMSource String, UTMMedium String, UTMCampaign String, UTMContent String, UTMTerm String, FromTag String, HasGCLID Int16, RefererHash Int64, URLHash Int64, CLID Int32', $$^WatchIDc*5/ !p~JavaEnableTitleGoodEventEventTime7ðâQEventDate>CounterIDClientIP®Æz·RegionIDGUserID× ’•:6×ÝCounterClassOSUserAgentURLRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionIDResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajorUserAgentMinor�OCookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID¯á9TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion2SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTime&·ãQAgeSexIncomeInterestsRobotnessRemoteIP^DIÄWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashÍ|3úÐb.‹CLID^WatchID úFÚÓ“2qJavaEnableTitleGoodEventEventTimen$äQEventDate>CounterIDClientIP®Æz·RegionIDGUserID× ’•:6×ÝCounterClassOSUserAgentURLRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionIDResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajorUserAgentMinor�OCookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID¯á9TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTimeǘãQAgeSexIncomeInterestsRobotnessRemoteIP^DIÄWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashÍ|3úÐb.‹CLID^WatchIDl!è–|¨@HJavaEnableTitleGoodEventEventTimeÃ)äQEventDate>CounterIDClientIP®Æz·RegionIDGUserID× ’•:6×ÝCounterClassOSUserAgentURLRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionIDResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajorUserAgentMinor�OCookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID¯á9TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTime}žãQAgeSexIncomeInterestsRobotnessRemoteIP^DIÄWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashÍ|3úÐb.‹CLID^WatchID²Ç=ÐŒWJavaEnableTitleGoodEventEventTime8*äQEventDate>CounterIDClientIP®Æz·RegionIDGUserID× ’•:6×ÝCounterClassOSUserAgentURLRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionIDResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajorUserAgentMinor�OCookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID¯á9TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTimeÝžãQAgeSexIncomeInterestsRobotnessRemoteIP^DIÄWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashÍ|3úÐb.‹CLID‹WatchIDéòˆE&LyJavaEnableTitleGoodEventEventTimeJîâQEventDate>CounterIDClientIPº‹I`RegionID'UserIDq—íJd8CounterClassOSUserAgentURL-http://holodilnik.ru/russia/05jul2013&model=0RefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryID¬9URLRegionIDResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajor UserAgentMinorD�CookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkIDŒd9TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqID%œlû©+kOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTime'¡ãQAgeSexIncomeInterests¦:RobotnessRemoteIP9ê3NWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashŽ oâïòeCLID¦WatchID¹ãk=÷±pJavaEnableTitleGoodEventEventTimeÉ ãQEventDate>CounterIDClientIP®Æz·RegionIDGUserID ÎKs}¡ïCounterClassOSUserAgentURLHhttp://afisha.mail.ru/catalog/314/women.ru/ency=1&page3/?errovat-pinnikiRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryID0=URLRegionIDØResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajorUserAgentMinorD�CookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID¯á9TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqID:¤ìWëÂmOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTimeA¶ãQAgeSexIncomeInterestsRobotnessRemoteIP^DIÄWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashý€ à#â\CLIDœWatchIDæ1þž oíCJavaEnableTitleGoodEventEventTimeµ0äQEventDate>CounterIDClientIPÉ^{]RegionIDÅUserID&n%Št"6CounterClassOS'UserAgentURL>http://bonprix.ru/index.ru/cinema/art/0 986 424 233 ÑезонRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionID±ResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajorUserAgentMinorD�CookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID‰#(TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTime¼£ãQAgeSexIncomeInterestsRobotnessRemoteIP…UWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashX-h³ýX CLID˜WatchID»-ÞC_JavaEnableTitleGoodEventEventTime83äQEventDate>CounterIDClientIPÉ^{]RegionIDÅUserID&n%Št"6CounterClassOS'UserAgentURL:http://bonprix.ru/index.ru/cinema/art/A00387,3797); ru)&bLRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionID±ResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajorUserAgentMinorD�CookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID‰#(TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTime ¦ãQAgeSexIncomeInterestsRobotnessRemoteIP…UWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashvÀvÍÀ‰ÇCLIDWatchIDìÒŒ\JavaEnableTitleGoodEventEventTime× äQEventDate>CounterIDClientIPgURegionIDåUserIDƒs—yyçófCounterClassOS,UserAgentURL1http://tours/Ekategoriya%2F&sr=http://slovareniyeRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionIDØesRolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajor UserAgentMinorD�CookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID¶œTraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTimeY’ãQAgeSexIncomeInterestsRobotnessRemoteIP€=kWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashh˜´9›DCLID^WatchIDÛ/E‚ÜJÛ{JavaEnableTitleGoodEventEventTimeÖ1ãQEventDate>CounterIDClientIP®Æz·RegionIDGUserID× ’•:6×ÝCounterClassOSUserAgentURLRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionIDResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajorUserAgentMinor�OCookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID¯á9TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTime‹ÏãQAgeSexIncomeInterestsRobotnessRemoteIP^DIÄWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashÍ|3úÐb.‹CLID$$);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x0000000008e1c4ca 4. ./build_docker/./src/Processors/Formats/Impl/BSONEachRowRowInputFormat.cpp:806: DB::BSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b2b6ab7 5. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b274d5f 6. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b108bd9 7. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 8. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 9. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000003b5ffbe5 10. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:95: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000003b5fbe27 11. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b6027bc 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 08:56:19.689381 [ 24842 ] {} TCPHandler: Code: 117. DB::Exception: Duplicate field found while parsing BSONEachRow format: SilverlightVersion2: (at row 1) : While executing ParallelParsingBlockInputFormat. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x0000000008e1c4ca 4. ./build_docker/./src/Processors/Formats/Impl/BSONEachRowRowInputFormat.cpp:806: DB::BSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b2b6ab7 5. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b274d5f 6. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b108bd9 7. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 8. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 9. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000003b5ffbe5 10. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:95: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000003b5fbe27 11. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b6027bc 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:293: DB::ParallelParsingInputFormat::scheduleParserThreadForUnitWithNumber(unsigned long) @ 0x000000003b5fec39 5. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:45: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x000000003b5fa53a 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x000000003b60654f 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b6061df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&) @ 0x000000003b60179d 5. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:158: DB::ParallelParsingInputFormat::read() @ 0x000000003b5fe482 6. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b108bd9 7. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 8. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b0f6008 14. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000266c3409 15. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d0326ad 16. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316edd5f 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030336f50 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 32. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 33. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 34. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 35. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 36. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 37. ? @ 0x00007f5206343ac3 38. ? @ 0x00007f52063d5850 2025.06.13 08:56:37.841542 [ 9224 ] {} TCPHandler: Code: 164. DB::Exception: Cannot modify 'min_compress_block_size' setting in readonly mode. (READONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x000000002659f49f 3. ./build_docker/./src/Access/SettingsConstraints.cpp:319: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e5fc757 4. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e5fb2e9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e5fba9c 6. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000316f4b4e 7. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000316f5cb0 8. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x000000003add1a84 9. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003adb6f72 10. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x000000003ad8c9f4 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 08:56:38.021769 [ 9224 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003adb75b3 5. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x000000003ad8c9f4 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 08:56:38.692948 [ 24861 ] {} TCPHandler: Code: 164. DB::Exception: Cannot modify 'min_compress_block_size' setting in readonly mode. (READONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x000000002659f49f 3. ./build_docker/./src/Access/SettingsConstraints.cpp:319: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e5fc757 4. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e5fb2e9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e5fba9c 6. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000316f4b4e 7. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000316f5cb0 8. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x000000003add1a84 9. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003adb6f72 10. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x000000003ad8c9f4 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 08:56:38.693610 [ 24861 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003adb75b3 5. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x000000003ad8c9f4 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 08:56:39.563832 [ 24861 ] {} TCPHandler: Code: 164. DB::Exception: Cannot modify 'min_compress_block_size' setting in readonly mode. (READONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x000000002659f49f 3. ./build_docker/./src/Access/SettingsConstraints.cpp:319: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e5fc757 4. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e5fb2e9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e5fba9c 6. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000316f4b4e 7. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000316f5cb0 8. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x000000003add1a84 9. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003adb6f72 10. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x000000003ad8c9f4 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 08:56:39.564673 [ 24861 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003adb75b3 5. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x000000003ad8c9f4 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 08:56:41.861628 [ 9237 ] {46d265b8-e1d2-4563-a959-66dc854c98f2} executeQuery: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58360) (comment: 00543_access_to_temporary_table_in_readonly_mode.sh) (query 2, line 3) (in query: INSERT INTO test_readonly (ID) VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002e30701f 4. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000002e3023a8 5. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x000000002e266ffb 6. ./src/Access/ContextAccess.h:259: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x00000000317725c9 7. ./build_docker/./src/Interpreters/Context.cpp:1762: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x00000000316d5323 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:843: DB::InterpreterInsertQuery::execute() @ 0x00000000329e305e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:56:41.871596 [ 9237 ] {} TCPHandler: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002e30701f 4. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000002e3023a8 5. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x000000002e266ffb 6. ./src/Access/ContextAccess.h:259: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x00000000317725c9 7. ./build_docker/./src/Interpreters/Context.cpp:1762: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x00000000316d5323 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:843: DB::InterpreterInsertQuery::execute() @ 0x00000000329e305e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:56:43.034975 [ 9260 ] {0ac707f4-f263-4013-ac9c-672a3219e406} executeQuery: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58384) (comment: 00543_access_to_temporary_table_in_readonly_mode.sh) (query 2, line 3) (in query: DROP TABLE test_readonly;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002e2f2ff1 4. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002e2ee408 5. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002e2667f8 6. ./src/Access/ContextAccess.h:256: void DB::Context::checkAccessImpl(DB::AccessFlags const&, String const&, String const&) const @ 0x000000003177164c 7. ./build_docker/./src/Interpreters/Context.cpp:1759: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&) const @ 0x00000000316d4b5e 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:286: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003296ddb2 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032968e1f 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965c79 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:56:43.044189 [ 9260 ] {} TCPHandler: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002e2f2ff1 4. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002e2ee408 5. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002e2667f8 6. ./src/Access/ContextAccess.h:256: void DB::Context::checkAccessImpl(DB::AccessFlags const&, String const&, String const&) const @ 0x000000003177164c 7. ./build_docker/./src/Interpreters/Context.cpp:1759: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&) const @ 0x00000000316d4b5e 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:286: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003296ddb2 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032968e1f 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965c79 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:56:48.137763 [ 2137 ] {762853d5-e78d-4cba-994d-4147da6fb3d6} executeQuery: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52778) (comment: 00534_filimonov.sh) (query 1, line 303) (in query: SELECT runningDifference(CAST(NULL AS Nullable(Float32)));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c2574a 4. DB::FunctionRunningDifferenceImpl::create(std::shared_ptr) @ 0x000000001a321c15 5. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl[abi:ne190107] (*)(std::shared_ptr), std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x0000000008ba5577 6. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl[abi:ne190107] (std::shared_ptr)>, DB::FunctionDocumentation, DB::IFactoryWithAliases (std::shared_ptr)>, DB::FunctionDocumentation>>::Case)::$_0, std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x000000002c023624 7. DB::FunctionFactory::tryGetImpl(String const&, std::shared_ptr) const @ 0x000000002c020e4b 8. DB::FunctionFactory::tryGet(String const&, std::shared_ptr) const @ 0x000000002c022dec 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3313: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037dd3a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:56:48.145559 [ 2137 ] {} TCPHandler: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c2574a 4. DB::FunctionRunningDifferenceImpl::create(std::shared_ptr) @ 0x000000001a321c15 5. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl[abi:ne190107] (*)(std::shared_ptr), std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x0000000008ba5577 6. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl[abi:ne190107] (std::shared_ptr)>, DB::FunctionDocumentation, DB::IFactoryWithAliases (std::shared_ptr)>, DB::FunctionDocumentation>>::Case)::$_0, std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x000000002c023624 7. DB::FunctionFactory::tryGetImpl(String const&, std::shared_ptr) const @ 0x000000002c020e4b 8. DB::FunctionFactory::tryGet(String const&, std::shared_ptr) const @ 0x000000002c022dec 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3313: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037dd3a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:56:48.274656 [ 2137 ] {ba7bb48b-f8e1-442d-bb22-3ac237c2b93c} executeQuery: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52778) (comment: 00534_filimonov.sh) (query 2, line 304) (in query: SELECT runningDifference(CAST(NULL AS Nullable(Float64)));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c2574a 4. DB::FunctionRunningDifferenceImpl::create(std::shared_ptr) @ 0x000000001a321c15 5. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl[abi:ne190107] (*)(std::shared_ptr), std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x0000000008ba5577 6. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl[abi:ne190107] (std::shared_ptr)>, DB::FunctionDocumentation, DB::IFactoryWithAliases (std::shared_ptr)>, DB::FunctionDocumentation>>::Case)::$_0, std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x000000002c023624 7. DB::FunctionFactory::tryGetImpl(String const&, std::shared_ptr) const @ 0x000000002c020e4b 8. DB::FunctionFactory::tryGet(String const&, std::shared_ptr) const @ 0x000000002c022dec 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3313: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037dd3a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:56:48.283406 [ 2137 ] {} TCPHandler: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c2574a 4. DB::FunctionRunningDifferenceImpl::create(std::shared_ptr) @ 0x000000001a321c15 5. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl[abi:ne190107] (*)(std::shared_ptr), std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x0000000008ba5577 6. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl[abi:ne190107] (std::shared_ptr)>, DB::FunctionDocumentation, DB::IFactoryWithAliases (std::shared_ptr)>, DB::FunctionDocumentation>>::Case)::$_0, std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x000000002c023624 7. DB::FunctionFactory::tryGetImpl(String const&, std::shared_ptr) const @ 0x000000002c020e4b 8. DB::FunctionFactory::tryGet(String const&, std::shared_ptr) const @ 0x000000002c022dec 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3313: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037dd3a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:56:48.322420 [ 2137 ] {dd48dd04-e930-4201-9ebc-3d3f973bc328} executeQuery: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52778) (comment: 00534_filimonov.sh) (query 3, line 305) (in query: SELECT runningDifference(CAST(NULL AS Nullable(Date)));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c2574a 4. DB::FunctionRunningDifferenceImpl::create(std::shared_ptr) @ 0x000000001a321c15 5. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl[abi:ne190107] (*)(std::shared_ptr), std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x0000000008ba5577 6. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl[abi:ne190107] (std::shared_ptr)>, DB::FunctionDocumentation, DB::IFactoryWithAliases (std::shared_ptr)>, DB::FunctionDocumentation>>::Case)::$_0, std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x000000002c023624 7. DB::FunctionFactory::tryGetImpl(String const&, std::shared_ptr) const @ 0x000000002c020e4b 8. DB::FunctionFactory::tryGet(String const&, std::shared_ptr) const @ 0x000000002c022dec 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3313: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037dd3a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:56:48.332880 [ 2137 ] {} TCPHandler: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c2574a 4. DB::FunctionRunningDifferenceImpl::create(std::shared_ptr) @ 0x000000001a321c15 5. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl[abi:ne190107] (*)(std::shared_ptr), std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x0000000008ba5577 6. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl[abi:ne190107] (std::shared_ptr)>, DB::FunctionDocumentation, DB::IFactoryWithAliases (std::shared_ptr)>, DB::FunctionDocumentation>>::Case)::$_0, std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x000000002c023624 7. DB::FunctionFactory::tryGetImpl(String const&, std::shared_ptr) const @ 0x000000002c020e4b 8. DB::FunctionFactory::tryGet(String const&, std::shared_ptr) const @ 0x000000002c022dec 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3313: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037dd3a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:56:48.360573 [ 24844 ] {c9a05e51-6a5b-45e4-b4aa-0e879c1409e3} executeQuery: Code: 70. DB::Exception: Field value -1 is out of range of unsigned long type. (CANNOT_CONVERT_TYPE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52796) (comment: 02992_settings_overflow.sql) (query 1, line 1) (in query: SET max_threads = -1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Field const&, String&&) @ 0x000000002f1199cd 4. ./build_docker/./src/Core/SettingsFields.cpp:75: unsigned long DB::(anonymous namespace)::fieldToNumber(DB::Field const&) @ 0x000000002f0fb512 5. ./build_docker/./src/Core/SettingsFields.cpp:231: DB::(anonymous namespace)::fieldToMaxThreads(DB::Field const&) @ 0x000000002f102d27 6. ./build_docker/./src/Core/SettingsFields.cpp:235: DB::SettingFieldMaxThreads::SettingFieldMaxThreads(DB::Field const&) @ 0x000000002f102c5c 7. ./build_docker/./src/Core/Settings.cpp:6239: DB::SettingsTraits::Accessor::instance()::$_0::operator()() const::'lambda33'(DB::Field const&)::__invoke(DB::Field const&) @ 0x000000002ed301f9 8. ./build_docker/./src/Core/Settings.cpp:6238: DB::BaseSettings::castValueUtil(std::basic_string_view>, DB::Field const&) @ 0x000000002ef23383 9. ./build_docker/./src/Core/Settings.cpp:6681: DB::Settings::castValueUtil(std::basic_string_view>, DB::Field const&) @ 0x000000002ed2992e 10. ./build_docker/./src/Access/SettingsConstraints.cpp:245: bool DB::getNewValueToCheck(DB::Settings const&, DB::SettingChange&, DB::Field&, bool) @ 0x000000002e5ff333 11. ./build_docker/./src/Access/SettingsConstraints.cpp:297: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e5fb1ea 12. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002e5fb97b 13. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000316f5875 14. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000032cad014 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:56:48.373196 [ 24844 ] {} TCPHandler: Code: 70. DB::Exception: Field value -1 is out of range of unsigned long type. (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Field const&, String&&) @ 0x000000002f1199cd 4. ./build_docker/./src/Core/SettingsFields.cpp:75: unsigned long DB::(anonymous namespace)::fieldToNumber(DB::Field const&) @ 0x000000002f0fb512 5. ./build_docker/./src/Core/SettingsFields.cpp:231: DB::(anonymous namespace)::fieldToMaxThreads(DB::Field const&) @ 0x000000002f102d27 6. ./build_docker/./src/Core/SettingsFields.cpp:235: DB::SettingFieldMaxThreads::SettingFieldMaxThreads(DB::Field const&) @ 0x000000002f102c5c 7. ./build_docker/./src/Core/Settings.cpp:6239: DB::SettingsTraits::Accessor::instance()::$_0::operator()() const::'lambda33'(DB::Field const&)::__invoke(DB::Field const&) @ 0x000000002ed301f9 8. ./build_docker/./src/Core/Settings.cpp:6238: DB::BaseSettings::castValueUtil(std::basic_string_view>, DB::Field const&) @ 0x000000002ef23383 9. ./build_docker/./src/Core/Settings.cpp:6681: DB::Settings::castValueUtil(std::basic_string_view>, DB::Field const&) @ 0x000000002ed2992e 10. ./build_docker/./src/Access/SettingsConstraints.cpp:245: bool DB::getNewValueToCheck(DB::Settings const&, DB::SettingChange&, DB::Field&, bool) @ 0x000000002e5ff333 11. ./build_docker/./src/Access/SettingsConstraints.cpp:297: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e5fb1ea 12. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002e5fb97b 13. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000316f5875 14. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000032cad014 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:56:48.383038 [ 2137 ] {710e0d6f-5487-4019-85cf-e935c6c6128b} executeQuery: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52778) (comment: 00534_filimonov.sh) (query 4, line 306) (in query: SELECT runningDifference(CAST(NULL AS Nullable(DateTime)));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c2574a 4. DB::FunctionRunningDifferenceImpl::create(std::shared_ptr) @ 0x000000001a321c15 5. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl[abi:ne190107] (*)(std::shared_ptr), std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x0000000008ba5577 6. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl[abi:ne190107] (std::shared_ptr)>, DB::FunctionDocumentation, DB::IFactoryWithAliases (std::shared_ptr)>, DB::FunctionDocumentation>>::Case)::$_0, std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x000000002c023624 7. DB::FunctionFactory::tryGetImpl(String const&, std::shared_ptr) const @ 0x000000002c020e4b 8. DB::FunctionFactory::tryGet(String const&, std::shared_ptr) const @ 0x000000002c022dec 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3313: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037dd3a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:56:48.393945 [ 2137 ] {} TCPHandler: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c2574a 4. DB::FunctionRunningDifferenceImpl::create(std::shared_ptr) @ 0x000000001a321c15 5. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl[abi:ne190107] (*)(std::shared_ptr), std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x0000000008ba5577 6. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl[abi:ne190107] (std::shared_ptr)>, DB::FunctionDocumentation, DB::IFactoryWithAliases (std::shared_ptr)>, DB::FunctionDocumentation>>::Case)::$_0, std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x000000002c023624 7. DB::FunctionFactory::tryGetImpl(String const&, std::shared_ptr) const @ 0x000000002c020e4b 8. DB::FunctionFactory::tryGet(String const&, std::shared_ptr) const @ 0x000000002c022dec 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3313: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037dd3a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:56:54.126105 [ 24857 ] {5fa08cd0-026e-4365-8cff-226468a9333a} executeQuery: Code: 344. DB::Exception: Experimental merges with CLEANUP are not allowed. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52842) (comment: 03357_replacing_min_age_cleanup.sh) (query 9, line 22) (in query: OPTIMIZE TABLE replacing FINAL CLEANUP;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:1673: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003a3e1a8c 5. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000033858e79 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:56:54.141425 [ 24857 ] {} TCPHandler: Code: 344. DB::Exception: Experimental merges with CLEANUP are not allowed. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:1673: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003a3e1a8c 5. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000033858e79 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:56:54.230202 [ 2137 ] {36f27d63-ce7c-4015-a1c6-39aea0fa1503} executeQuery: Code: 43. DB::Exception: First argument for function tupleElement must be tuple or array of tuple. Actual Int8: In scope SELECT tupleElement(CAST(1, 'Int8'), sumState(0)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52778) (comment: 00534_filimonov.sh) (query 70, line 373) (in query: SELECT tupleElement(CAST(1 AS Int8),sumState(0));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001ad9ac6e 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:56:54.244239 [ 2137 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function tupleElement must be tuple or array of tuple. Actual Int8: In scope SELECT tupleElement(CAST(1, 'Int8'), sumState(0)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001ad9ac6e 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:56:55.105121 [ 2137 ] {dd334143-5738-470f-83fd-dd38abbb595c} executeQuery: Code: 43. DB::Exception: Illegal type (Nullable(Date)) of 2 argument of function or: In scope SELECT CAST(1, 'Int8') OR CAST(0, 'Nullable(Date)'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52778) (comment: 00534_filimonov.sh) (query 78, line 381) (in query: SELECT or(CAST(1 AS Int8),CAST( 0 AS Nullable(Date)));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000008bd1817 4. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002c1440c5 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:56:55.120107 [ 2137 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type (Nullable(Date)) of 2 argument of function or: In scope SELECT CAST(1, 'Int8') OR CAST(0, 'Nullable(Date)'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000008bd1817 4. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002c1440c5 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:56:55.156750 [ 2137 ] {ab3930f3-bd30-48a8-a692-2153b8c41e98} executeQuery: Code: 43. DB::Exception: Illegal type (Nullable(DateTime)) of 2 argument of function or: In scope SELECT CAST(1, 'Int8') OR CAST(0, 'Nullable(DateTime)'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52778) (comment: 00534_filimonov.sh) (query 79, line 382) (in query: SELECT or(CAST(1 AS Int8),CAST( 0 AS Nullable(DateTime)));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000008bd1817 4. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002c1440c5 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:56:55.165844 [ 2137 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type (Nullable(DateTime)) of 2 argument of function or: In scope SELECT CAST(1, 'Int8') OR CAST(0, 'Nullable(DateTime)'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000008bd1817 4. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002c1440c5 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:56:55.212015 [ 2137 ] {cd9add18-d99b-4217-8ad0-022d3b0fdc35} executeQuery: Code: 43. DB::Exception: Illegal type (Nullable(Enum8('0' = 0, 'z' = 1))) of 2 argument of function or: In scope SELECT CAST(1, 'Int8') OR CAST('0', 'Nullable(Enum8(\'0\' = 0, \'z\' = 1))'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52778) (comment: 00534_filimonov.sh) (query 80, line 383) (in query: SELECT or(CAST(1 AS Int8),CAST( '0' AS Nullable(Enum8('0' = 0, 'z' = 1))));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000008bd1817 4. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002c1440c5 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:56:55.220969 [ 2137 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type (Nullable(Enum8('0' = 0, 'z' = 1))) of 2 argument of function or: In scope SELECT CAST(1, 'Int8') OR CAST('0', 'Nullable(Enum8(\'0\' = 0, \'z\' = 1))'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000008bd1817 4. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002c1440c5 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:56:55.394512 [ 2137 ] {1ce56b96-9252-45e6-8fe7-12b4d1c16382} executeQuery: Code: 43. DB::Exception: Illegal type (Nullable(Date)) of 2 argument of function or: In scope SELECT CAST(1, 'Int8') OR CAST(NULL, 'Nullable(Date)'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52778) (comment: 00534_filimonov.sh) (query 82, line 385) (in query: SELECT or(CAST(1 AS Int8),CAST(NULL AS Nullable(Date)));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000008bd1817 4. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002c1440c5 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:56:55.405072 [ 2137 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type (Nullable(Date)) of 2 argument of function or: In scope SELECT CAST(1, 'Int8') OR CAST(NULL, 'Nullable(Date)'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000008bd1817 4. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002c1440c5 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:56:55.459701 [ 2137 ] {8443c7f5-133f-41ec-be38-464c253ae14c} executeQuery: Code: 43. DB::Exception: Illegal type (Nullable(DateTime)) of 2 argument of function or: In scope SELECT CAST(1, 'Int8') OR CAST(NULL, 'Nullable(DateTime)'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52778) (comment: 00534_filimonov.sh) (query 83, line 386) (in query: SELECT or(CAST(1 AS Int8),CAST(NULL AS Nullable(DateTime)));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000008bd1817 4. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002c1440c5 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:56:55.471129 [ 2137 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type (Nullable(DateTime)) of 2 argument of function or: In scope SELECT CAST(1, 'Int8') OR CAST(NULL, 'Nullable(DateTime)'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000008bd1817 4. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002c1440c5 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:56:55.519474 [ 2137 ] {08ca0962-a720-47a7-9ee6-95fd4c700d0a} executeQuery: Code: 43. DB::Exception: Illegal type (Nullable(DateTime)) of 2 argument of function or: In scope SELECT CAST(1, 'Int64') OR CAST(NULL, 'Nullable(DateTime)'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52778) (comment: 00534_filimonov.sh) (query 84, line 387) (in query: SELECT or(CAST(1 AS Int64),CAST(NULL AS Nullable(DateTime)));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000008bd1817 4. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002c1440c5 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:56:55.529588 [ 2137 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type (Nullable(DateTime)) of 2 argument of function or: In scope SELECT CAST(1, 'Int64') OR CAST(NULL, 'Nullable(DateTime)'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000008bd1817 4. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002c1440c5 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:56:56.163728 [ 1024 ] {c5fc985c-d1c4-4f92-9fa1-ac261ba5b98b::all_1_20_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x000000003968bba7 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:921: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::finalize() const @ 0x00000000396c3c9c 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:882: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000396c3902 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000396bdc00 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000396d5401 9. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a471407 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:56:56.638415 [ 2137 ] {a47c020d-7c13-4c42-b0b6-9cd529994c2e} executeQuery: Code: 44. DB::Exception: Second argument for function toFixedString must be unsigned integer: In scope SELECT toFixedString('', CAST(9223372036854775807, 'Int64')). (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52778) (comment: 00534_filimonov.sh) (query 94, line 398) (in query: SELECT toFixedString('',CAST(9223372036854775807 as Int64));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::FunctionToFixedString::getReturnTypeImpl(std::vector> const&) const @ 0x000000001aa3e60d 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:56:56.647163 [ 2137 ] {} TCPHandler: Code: 44. DB::Exception: Second argument for function toFixedString must be unsigned integer: In scope SELECT toFixedString('', CAST(9223372036854775807, 'Int64')). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::FunctionToFixedString::getReturnTypeImpl(std::vector> const&) const @ 0x000000001aa3e60d 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:56:57.369513 [ 15865 ] {2bbfe70f-94f0-4cea-8b7f-d561a3669c02} executeQuery: Code: 403. DB::Exception: Illegal expression '1' in JOIN ON section: While processing 1. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54960) (comment: 02498_storage_join_key_positions_old_analyzer.gen.sql) (query 26, line 37) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON t1.key1 = tj.key1 AND t1.key3 = tj.key3 AND t1.key2 = tj.key2 AND 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./src/Interpreters/CollectJoinOnKeysVisitor.h:76: DB::CollectJoinOnKeysMatcher::visit(std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x0000000033543df2 5. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033543855 6. ./src/Interpreters/InDepthNodeVisitor.h:61: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x00000000335441c4 7. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x00000000335441cf 8. ./src/Interpreters/InDepthNodeVisitor.h:64: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x000000003351526d 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:761: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a318d1 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 13. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 15. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:56:57.375423 [ 15865 ] {} TCPHandler: Code: 403. DB::Exception: Illegal expression '1' in JOIN ON section: While processing 1. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./src/Interpreters/CollectJoinOnKeysVisitor.h:76: DB::CollectJoinOnKeysMatcher::visit(std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x0000000033543df2 5. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033543855 6. ./src/Interpreters/InDepthNodeVisitor.h:61: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x00000000335441c4 7. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x00000000335441cf 8. ./src/Interpreters/InDepthNodeVisitor.h:64: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x000000003351526d 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:761: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a318d1 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 13. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 15. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:56:57.408156 [ 15865 ] {7b9dbf06-9c2c-4929-a894-08190ff8c1ff} executeQuery: Code: 403. DB::Exception: Illegal expression '0' in JOIN ON section: While processing 0. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54960) (comment: 02498_storage_join_key_positions_old_analyzer.gen.sql) (query 27, line 38) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON t1.key1 = tj.key1 AND t1.key3 = tj.key3 AND t1.key2 = tj.key2 AND 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./src/Interpreters/CollectJoinOnKeysVisitor.h:76: DB::CollectJoinOnKeysMatcher::visit(std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x0000000033543df2 5. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033543855 6. ./src/Interpreters/InDepthNodeVisitor.h:61: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x00000000335441c4 7. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x00000000335441cf 8. ./src/Interpreters/InDepthNodeVisitor.h:64: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x000000003351526d 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:761: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a318d1 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 13. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 15. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:56:57.418951 [ 15865 ] {} TCPHandler: Code: 403. DB::Exception: Illegal expression '0' in JOIN ON section: While processing 0. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./src/Interpreters/CollectJoinOnKeysVisitor.h:76: DB::CollectJoinOnKeysMatcher::visit(std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x0000000033543df2 5. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033543855 6. ./src/Interpreters/InDepthNodeVisitor.h:61: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x00000000335441c4 7. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x00000000335441cf 8. ./src/Interpreters/InDepthNodeVisitor.h:64: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x000000003351526d 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:761: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a318d1 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 13. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 15. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:56:57.699969 [ 15865 ] {f749cc30-9fa6-4b23-b8b5-b70507fd8157} executeQuery: Code: 403. DB::Exception: Unsupported JOIN ON conditions. Unexpected '1 > 1': While processing 1 > 1. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54960) (comment: 02498_storage_join_key_positions_old_analyzer.gen.sql) (query 28, line 39) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON t1.key1 = tj.key1 AND t1.key3 = tj.key3 AND t1.key2 = tj.key2 AND 1 > 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/CollectJoinOnKeysVisitor.cpp:150: DB::CollectJoinOnKeysMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x000000003360d5c2 5. ./src/Interpreters/CollectJoinOnKeysVisitor.h:67: DB::CollectJoinOnKeysMatcher::visit(std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x0000000033543bb5 6. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033543855 7. ./src/Interpreters/InDepthNodeVisitor.h:61: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x00000000335441c4 8. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x00000000335441cf 9. ./src/Interpreters/InDepthNodeVisitor.h:64: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x000000003351526d 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:761: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a318d1 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 16. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:56:57.707646 [ 15865 ] {} TCPHandler: Code: 403. DB::Exception: Unsupported JOIN ON conditions. Unexpected '1 > 1': While processing 1 > 1. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/CollectJoinOnKeysVisitor.cpp:150: DB::CollectJoinOnKeysMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x000000003360d5c2 5. ./src/Interpreters/CollectJoinOnKeysVisitor.h:67: DB::CollectJoinOnKeysMatcher::visit(std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x0000000033543bb5 6. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033543855 7. ./src/Interpreters/InDepthNodeVisitor.h:61: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x00000000335441c4 8. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x00000000335441cf 9. ./src/Interpreters/InDepthNodeVisitor.h:64: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x000000003351526d 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:761: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a318d1 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 16. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:56:58.009124 [ 15865 ] {e441d4a9-a59c-4780-a87b-b2f8d7e04955} executeQuery: Code: 403. DB::Exception: Illegal expression '1' in JOIN ON section: While processing 1. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54960) (comment: 02498_storage_join_key_positions_old_analyzer.gen.sql) (query 30, line 42) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./src/Interpreters/CollectJoinOnKeysVisitor.h:76: DB::CollectJoinOnKeysMatcher::visit(std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x0000000033543df2 5. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033543855 6. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x000000003351525a 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:761: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a318d1 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 11. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 13. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:56:58.015676 [ 15865 ] {} TCPHandler: Code: 403. DB::Exception: Illegal expression '1' in JOIN ON section: While processing 1. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./src/Interpreters/CollectJoinOnKeysVisitor.h:76: DB::CollectJoinOnKeysMatcher::visit(std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x0000000033543df2 5. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033543855 6. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x000000003351525a 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:761: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a318d1 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 11. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 13. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:56:58.047571 [ 15865 ] {5e607cdd-e36b-48a6-b17b-0f1e7c6a705c} executeQuery: Code: 403. DB::Exception: Illegal expression '0' in JOIN ON section: While processing 0. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54960) (comment: 02498_storage_join_key_positions_old_analyzer.gen.sql) (query 31, line 43) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./src/Interpreters/CollectJoinOnKeysVisitor.h:76: DB::CollectJoinOnKeysMatcher::visit(std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x0000000033543df2 5. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033543855 6. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x000000003351525a 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:761: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a318d1 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 11. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 13. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:56:58.054023 [ 15865 ] {} TCPHandler: Code: 403. DB::Exception: Illegal expression '0' in JOIN ON section: While processing 0. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./src/Interpreters/CollectJoinOnKeysVisitor.h:76: DB::CollectJoinOnKeysMatcher::visit(std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x0000000033543df2 5. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033543855 6. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x000000003351525a 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:761: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a318d1 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 11. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 13. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:56:58.088750 [ 15865 ] {b3d4e25a-47bd-4730-9983-35f0c4dd2f05} executeQuery: Code: 403. DB::Exception: Illegal expression 'NULL' in JOIN ON section: While processing NULL. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54960) (comment: 02498_storage_join_key_positions_old_analyzer.gen.sql) (query 32, line 44) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON NULL;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./src/Interpreters/CollectJoinOnKeysVisitor.h:76: DB::CollectJoinOnKeysMatcher::visit(std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x0000000033543df2 5. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033543855 6. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x000000003351525a 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:761: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a318d1 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 11. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 13. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:56:58.097034 [ 15865 ] {} TCPHandler: Code: 403. DB::Exception: Illegal expression 'NULL' in JOIN ON section: While processing NULL. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./src/Interpreters/CollectJoinOnKeysVisitor.h:76: DB::CollectJoinOnKeysMatcher::visit(std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x0000000033543df2 5. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033543855 6. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x000000003351525a 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:761: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a318d1 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 11. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 13. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 08:56:58.365400 [ 15865 ] {87275082-b3d1-4408-9069-f3d408c35aee} executeQuery: Code: 403. DB::Exception: Unsupported JOIN ON conditions. Unexpected '1 != 1': While processing 1 != 1. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54960) (comment: 02498_storage_join_key_positions_old_analyzer.gen.sql) (query 33, line 45) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON 1 != 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/CollectJoinOnKeysVisitor.cpp:150: DB::CollectJoinOnKeysMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x000000003360d5c2 5. ./src/Interpreters/CollectJoinOnKeysVisitor.h:67: DB::CollectJoinOnKeysMatcher::visit(std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x0000000033543bb5 6. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033543855 7. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x000000003351525a 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:761: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a318d1 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 12. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:56:58.371074 [ 15865 ] {} TCPHandler: Code: 403. DB::Exception: Unsupported JOIN ON conditions. Unexpected '1 != 1': While processing 1 != 1. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/CollectJoinOnKeysVisitor.cpp:150: DB::CollectJoinOnKeysMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x000000003360d5c2 5. ./src/Interpreters/CollectJoinOnKeysVisitor.h:67: DB::CollectJoinOnKeysMatcher::visit(std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x0000000033543bb5 6. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033543855 7. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x000000003351525a 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:761: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a318d1 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 12. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:56:58.617518 [ 15865 ] {edee702f-9942-4bae-9945-3baedc5a1620} executeQuery: Code: 352. DB::Exception: Ambiguous columns in expression '1 = 1' in JOIN ON section: While processing 1 = 1. (AMBIGUOUS_COLUMN_NAME) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54960) (comment: 02498_storage_join_key_positions_old_analyzer.gen.sql) (query 34, line 49) (in query: -- Here is another error code because equality is handled differently in CollectJoinOnKeysVisitor. -- We can change the error code, but it will become inconsistent for other cases -- where we actually expect AMBIGUOUS_COLUMN_NAME instead of INVALID_JOIN_ON_EXPRESSION/INCOMPATIBLE_TYPE_OF_JOIN. -- These checks are more reliable after switching to a new analyzer, they return INCOMPATIBLE_TYPE_OF_JOIN consistent with cases above SELECT * FROM t1 ALL INNER JOIN tj ON t1.key1 = tj.key1 AND t1.key3 = tj.key3 AND t1.key2 = tj.key2 AND 1 == 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/CollectJoinOnKeysVisitor.cpp:114: DB::CollectJoinOnKeysMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x000000003360dac1 5. ./src/Interpreters/CollectJoinOnKeysVisitor.h:67: DB::CollectJoinOnKeysMatcher::visit(std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x0000000033543bb5 6. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033543855 7. ./src/Interpreters/InDepthNodeVisitor.h:61: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x00000000335441c4 8. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x00000000335441cf 9. ./src/Interpreters/InDepthNodeVisitor.h:64: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x000000003351526d 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:761: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a318d1 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 16. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:56:58.623331 [ 15865 ] {} TCPHandler: Code: 352. DB::Exception: Ambiguous columns in expression '1 = 1' in JOIN ON section: While processing 1 = 1. (AMBIGUOUS_COLUMN_NAME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/CollectJoinOnKeysVisitor.cpp:114: DB::CollectJoinOnKeysMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x000000003360dac1 5. ./src/Interpreters/CollectJoinOnKeysVisitor.h:67: DB::CollectJoinOnKeysMatcher::visit(std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x0000000033543bb5 6. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033543855 7. ./src/Interpreters/InDepthNodeVisitor.h:61: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x00000000335441c4 8. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x00000000335441cf 9. ./src/Interpreters/InDepthNodeVisitor.h:64: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x000000003351526d 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:761: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a318d1 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 16. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:56:58.835051 [ 15865 ] {57954472-43ec-40af-b423-14b66f8f5a5d} executeQuery: Code: 352. DB::Exception: Ambiguous columns in expression '1 = 1' in JOIN ON section: While processing 1 = 1. (AMBIGUOUS_COLUMN_NAME) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54960) (comment: 02498_storage_join_key_positions_old_analyzer.gen.sql) (query 35, line 54) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON 1 == 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/CollectJoinOnKeysVisitor.cpp:114: DB::CollectJoinOnKeysMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x000000003360dac1 5. ./src/Interpreters/CollectJoinOnKeysVisitor.h:67: DB::CollectJoinOnKeysMatcher::visit(std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x0000000033543bb5 6. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033543855 7. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x000000003351525a 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:761: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a318d1 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 12. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:56:58.841195 [ 15865 ] {} TCPHandler: Code: 352. DB::Exception: Ambiguous columns in expression '1 = 1' in JOIN ON section: While processing 1 = 1. (AMBIGUOUS_COLUMN_NAME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/CollectJoinOnKeysVisitor.cpp:114: DB::CollectJoinOnKeysMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x000000003360dac1 5. ./src/Interpreters/CollectJoinOnKeysVisitor.h:67: DB::CollectJoinOnKeysMatcher::visit(std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x0000000033543bb5 6. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033543855 7. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x000000003351525a 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:761: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a318d1 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 12. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:56:58.870448 [ 15865 ] {d9a5c03e-60c0-4e3b-a273-e4ffce24f85a} executeQuery: Code: 352. DB::Exception: Ambiguous columns in expression '1 = 2' in JOIN ON section: While processing 1 = 2. (AMBIGUOUS_COLUMN_NAME) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54960) (comment: 02498_storage_join_key_positions_old_analyzer.gen.sql) (query 36, line 55) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON 1 == 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/CollectJoinOnKeysVisitor.cpp:114: DB::CollectJoinOnKeysMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x000000003360dac1 5. ./src/Interpreters/CollectJoinOnKeysVisitor.h:67: DB::CollectJoinOnKeysMatcher::visit(std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x0000000033543bb5 6. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033543855 7. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x000000003351525a 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:761: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a318d1 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 12. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:56:58.876000 [ 15865 ] {} TCPHandler: Code: 352. DB::Exception: Ambiguous columns in expression '1 = 2' in JOIN ON section: While processing 1 = 2. (AMBIGUOUS_COLUMN_NAME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/CollectJoinOnKeysVisitor.cpp:114: DB::CollectJoinOnKeysMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x000000003360dac1 5. ./src/Interpreters/CollectJoinOnKeysVisitor.h:67: DB::CollectJoinOnKeysMatcher::visit(std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x0000000033543bb5 6. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000033543855 7. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x000000003351525a 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:761: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a318d1 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 12. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:56:59.155234 [ 15865 ] {c4874bab-889a-47d3-b2f1-9ba0e502c055} executeQuery: Code: 264. DB::Exception: Key 'key3' not found in JOIN ON section. Join engine keys 'key3, key2, key1' have to be used. (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54960) (comment: 02498_storage_join_key_positions_old_analyzer.gen.sql) (query 37, line 59) (in query: SELECT * FROM t1 ALL INNER JOIN tj USING (key1, key2, attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity, std::__wrap_iter, char>>::type>, String const&, char const*&&, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x00000000384e6bb7 4. ./build_docker/./src/Storages/StorageJoin.cpp:288: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x00000000384ddaee 5. ./build_docker/./src/Storages/StorageJoin.cpp:318: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000384df5af 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1205: DB::SelectQueryExpressionAnalyzer::makeJoin(DB::ASTTablesInSelectQueryElement const&, std::vector> const&, std::optional&) @ 0x0000000031ae92b2 7. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:976: DB::SelectQueryExpressionAnalyzer::appendJoin(DB::ExpressionActionsChain&, std::shared_ptr&) @ 0x0000000031ae63bb 8. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2067: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b1494b 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 16. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:56:59.160387 [ 15865 ] {} TCPHandler: Code: 264. DB::Exception: Key 'key3' not found in JOIN ON section. Join engine keys 'key3, key2, key1' have to be used. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity, std::__wrap_iter, char>>::type>, String const&, char const*&&, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x00000000384e6bb7 4. ./build_docker/./src/Storages/StorageJoin.cpp:288: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x00000000384ddaee 5. ./build_docker/./src/Storages/StorageJoin.cpp:318: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000384df5af 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1205: DB::SelectQueryExpressionAnalyzer::makeJoin(DB::ASTTablesInSelectQueryElement const&, std::vector> const&, std::optional&) @ 0x0000000031ae92b2 7. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:976: DB::SelectQueryExpressionAnalyzer::appendJoin(DB::ExpressionActionsChain&, std::shared_ptr&) @ 0x0000000031ae63bb 8. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2067: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b1494b 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 16. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:56:59.197839 [ 2137 ] {ff4e9451-837e-4af3-b4db-b0b71e104194} executeQuery: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(sumState(0), CAST(1, 'Int8')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52778) (comment: 00534_filimonov.sh) (query 122, line 426) (in query: SELECT arrayReduce(sumState(0),CAST(1 AS Int8));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x000000001e2aeef9 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7eb0 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:56:59.208474 [ 2137 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(sumState(0), CAST(1, 'Int8')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x000000001e2aeef9 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7eb0 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:56:59.391367 [ 15865 ] {eb7eb0e3-c52e-4a94-998f-5261d3c116ba} executeQuery: Code: 264. DB::Exception: Number of keys in JOIN ON section (4) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54960) (comment: 02498_storage_join_key_positions_old_analyzer.gen.sql) (query 38, line 60) (in query: SELECT * FROM t1 ALL INNER JOIN tj USING (key1, key2, key3, attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x000000001f509a6d 4. ./build_docker/./src/Storages/StorageJoin.cpp:264: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x00000000384ddef8 5. ./build_docker/./src/Storages/StorageJoin.cpp:318: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000384df5af 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1205: DB::SelectQueryExpressionAnalyzer::makeJoin(DB::ASTTablesInSelectQueryElement const&, std::vector> const&, std::optional&) @ 0x0000000031ae92b2 7. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:976: DB::SelectQueryExpressionAnalyzer::appendJoin(DB::ExpressionActionsChain&, std::shared_ptr&) @ 0x0000000031ae63bb 8. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2067: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b1494b 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 16. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:56:59.396402 [ 15865 ] {} TCPHandler: Code: 264. DB::Exception: Number of keys in JOIN ON section (4) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x000000001f509a6d 4. ./build_docker/./src/Storages/StorageJoin.cpp:264: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x00000000384ddef8 5. ./build_docker/./src/Storages/StorageJoin.cpp:318: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000384df5af 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1205: DB::SelectQueryExpressionAnalyzer::makeJoin(DB::ASTTablesInSelectQueryElement const&, std::vector> const&, std::optional&) @ 0x0000000031ae92b2 7. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:976: DB::SelectQueryExpressionAnalyzer::appendJoin(DB::ExpressionActionsChain&, std::shared_ptr&) @ 0x0000000031ae63bb 8. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2067: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b1494b 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 16. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:56:59.427447 [ 15865 ] {c10c5a2f-9138-4689-85ad-1abbc131f827} executeQuery: Code: 264. DB::Exception: Number of keys in JOIN ON section (2) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54960) (comment: 02498_storage_join_key_positions_old_analyzer.gen.sql) (query 39, line 62) (in query: SELECT * FROM t1 ALL INNER JOIN tj USING (key2, key3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x000000001f509a6d 4. ./build_docker/./src/Storages/StorageJoin.cpp:264: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x00000000384ddef8 5. ./build_docker/./src/Storages/StorageJoin.cpp:318: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000384df5af 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1205: DB::SelectQueryExpressionAnalyzer::makeJoin(DB::ASTTablesInSelectQueryElement const&, std::vector> const&, std::optional&) @ 0x0000000031ae92b2 7. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:976: DB::SelectQueryExpressionAnalyzer::appendJoin(DB::ExpressionActionsChain&, std::shared_ptr&) @ 0x0000000031ae63bb 8. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2067: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b1494b 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 16. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:56:59.428583 [ 2137 ] {dd5ee1d1-a79f-4d2c-8f7b-a5b886e314b6} executeQuery: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52778) (comment: 00534_filimonov.sh) (query 125, line 429) (in query: SELECT runningDifference(CAST( 0 AS Nullable(Int8)));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c2574a 4. DB::FunctionRunningDifferenceImpl::create(std::shared_ptr) @ 0x000000001a321c15 5. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl[abi:ne190107] (*)(std::shared_ptr), std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x0000000008ba5577 6. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl[abi:ne190107] (std::shared_ptr)>, DB::FunctionDocumentation, DB::IFactoryWithAliases (std::shared_ptr)>, DB::FunctionDocumentation>>::Case)::$_0, std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x000000002c023624 7. DB::FunctionFactory::tryGetImpl(String const&, std::shared_ptr) const @ 0x000000002c020e4b 8. DB::FunctionFactory::tryGet(String const&, std::shared_ptr) const @ 0x000000002c022dec 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3313: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037dd3a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:56:59.432375 [ 15865 ] {} TCPHandler: Code: 264. DB::Exception: Number of keys in JOIN ON section (2) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x000000001f509a6d 4. ./build_docker/./src/Storages/StorageJoin.cpp:264: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x00000000384ddef8 5. ./build_docker/./src/Storages/StorageJoin.cpp:318: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000384df5af 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1205: DB::SelectQueryExpressionAnalyzer::makeJoin(DB::ASTTablesInSelectQueryElement const&, std::vector> const&, std::optional&) @ 0x0000000031ae92b2 7. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:976: DB::SelectQueryExpressionAnalyzer::appendJoin(DB::ExpressionActionsChain&, std::shared_ptr&) @ 0x0000000031ae63bb 8. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2067: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b1494b 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 16. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:56:59.438213 [ 2137 ] {} TCPHandler: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c2574a 4. DB::FunctionRunningDifferenceImpl::create(std::shared_ptr) @ 0x000000001a321c15 5. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl[abi:ne190107] (*)(std::shared_ptr), std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x0000000008ba5577 6. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl[abi:ne190107] (std::shared_ptr)>, DB::FunctionDocumentation, DB::IFactoryWithAliases (std::shared_ptr)>, DB::FunctionDocumentation>>::Case)::$_0, std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x000000002c023624 7. DB::FunctionFactory::tryGetImpl(String const&, std::shared_ptr) const @ 0x000000002c020e4b 8. DB::FunctionFactory::tryGet(String const&, std::shared_ptr) const @ 0x000000002c022dec 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3313: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003037dd3a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:56:59.483820 [ 15865 ] {e096417c-893a-42c3-88dc-697d73472219} executeQuery: Code: 264. DB::Exception: Number of keys in JOIN ON section (1) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54960) (comment: 02498_storage_join_key_positions_old_analyzer.gen.sql) (query 40, line 63) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON t1.key1 = tj.attr;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x000000001f509a6d 4. ./build_docker/./src/Storages/StorageJoin.cpp:264: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x00000000384ddef8 5. ./build_docker/./src/Storages/StorageJoin.cpp:318: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000384df5af 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1205: DB::SelectQueryExpressionAnalyzer::makeJoin(DB::ASTTablesInSelectQueryElement const&, std::vector> const&, std::optional&) @ 0x0000000031ae92b2 7. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:976: DB::SelectQueryExpressionAnalyzer::appendJoin(DB::ExpressionActionsChain&, std::shared_ptr&) @ 0x0000000031ae63bb 8. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2067: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b1494b 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 16. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:56:59.490989 [ 15865 ] {} TCPHandler: Code: 264. DB::Exception: Number of keys in JOIN ON section (1) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x000000001f509a6d 4. ./build_docker/./src/Storages/StorageJoin.cpp:264: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x00000000384ddef8 5. ./build_docker/./src/Storages/StorageJoin.cpp:318: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000384df5af 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1205: DB::SelectQueryExpressionAnalyzer::makeJoin(DB::ASTTablesInSelectQueryElement const&, std::vector> const&, std::optional&) @ 0x0000000031ae92b2 7. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:976: DB::SelectQueryExpressionAnalyzer::appendJoin(DB::ExpressionActionsChain&, std::shared_ptr&) @ 0x0000000031ae63bb 8. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2067: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b1494b 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 16. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:56:59.541511 [ 15865 ] {e2abd69f-51dc-45c7-8f06-256cd73a1a3f} executeQuery: Code: 264. DB::Exception: Number of keys in JOIN ON section (1) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54960) (comment: 02498_storage_join_key_positions_old_analyzer.gen.sql) (query 41, line 64) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON t1.key1 = tj.key1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x000000001f509a6d 4. ./build_docker/./src/Storages/StorageJoin.cpp:264: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x00000000384ddef8 5. ./build_docker/./src/Storages/StorageJoin.cpp:318: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000384df5af 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1205: DB::SelectQueryExpressionAnalyzer::makeJoin(DB::ASTTablesInSelectQueryElement const&, std::vector> const&, std::optional&) @ 0x0000000031ae92b2 7. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:976: DB::SelectQueryExpressionAnalyzer::appendJoin(DB::ExpressionActionsChain&, std::shared_ptr&) @ 0x0000000031ae63bb 8. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2067: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b1494b 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 16. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:56:59.547829 [ 15865 ] {} TCPHandler: Code: 264. DB::Exception: Number of keys in JOIN ON section (1) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x000000001f509a6d 4. ./build_docker/./src/Storages/StorageJoin.cpp:264: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x00000000384ddef8 5. ./build_docker/./src/Storages/StorageJoin.cpp:318: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000384df5af 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1205: DB::SelectQueryExpressionAnalyzer::makeJoin(DB::ASTTablesInSelectQueryElement const&, std::vector> const&, std::optional&) @ 0x0000000031ae92b2 7. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:976: DB::SelectQueryExpressionAnalyzer::appendJoin(DB::ExpressionActionsChain&, std::shared_ptr&) @ 0x0000000031ae63bb 8. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2067: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b1494b 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 16. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:56:59.590715 [ 15865 ] {f114086d-e613-49ba-b463-7a942a26ab80} executeQuery: Code: 264. DB::Exception: Key 'key3' not found in JOIN ON section. Join engine keys 'key3, key2, key1' have to be used. (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54960) (comment: 02498_storage_join_key_positions_old_analyzer.gen.sql) (query 42, line 65) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON t1.key1 = tj.key1 AND t1.key2 = tj.key2 AND t1.key3 = tj.attr;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity, std::__wrap_iter, char>>::type>, String const&, char const*&&, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x00000000384e6bb7 4. ./build_docker/./src/Storages/StorageJoin.cpp:288: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x00000000384ddaee 5. ./build_docker/./src/Storages/StorageJoin.cpp:318: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000384df5af 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1205: DB::SelectQueryExpressionAnalyzer::makeJoin(DB::ASTTablesInSelectQueryElement const&, std::vector> const&, std::optional&) @ 0x0000000031ae92b2 7. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:976: DB::SelectQueryExpressionAnalyzer::appendJoin(DB::ExpressionActionsChain&, std::shared_ptr&) @ 0x0000000031ae63bb 8. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2067: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b1494b 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 16. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:56:59.598634 [ 15865 ] {} TCPHandler: Code: 264. DB::Exception: Key 'key3' not found in JOIN ON section. Join engine keys 'key3, key2, key1' have to be used. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity, std::__wrap_iter, char>>::type>, String const&, char const*&&, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x00000000384e6bb7 4. ./build_docker/./src/Storages/StorageJoin.cpp:288: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x00000000384ddaee 5. ./build_docker/./src/Storages/StorageJoin.cpp:318: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000384df5af 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1205: DB::SelectQueryExpressionAnalyzer::makeJoin(DB::ASTTablesInSelectQueryElement const&, std::vector> const&, std::optional&) @ 0x0000000031ae92b2 7. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:976: DB::SelectQueryExpressionAnalyzer::appendJoin(DB::ExpressionActionsChain&, std::shared_ptr&) @ 0x0000000031ae63bb 8. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2067: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b1494b 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 16. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:56:59.664223 [ 15865 ] {fd8167be-fb81-4cd1-8234-caf8e94b87db} executeQuery: Code: 264. DB::Exception: Number of keys in JOIN ON section (4) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54960) (comment: 02498_storage_join_key_positions_old_analyzer.gen.sql) (query 43, line 66) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON t1.key1 = tj.key1 AND t1.key2 = tj.key2 AND t1.key3 = tj.key3 AND t1.key1 = tj.key1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x000000001f509a6d 4. ./build_docker/./src/Storages/StorageJoin.cpp:264: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x00000000384ddef8 5. ./build_docker/./src/Storages/StorageJoin.cpp:318: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000384df5af 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1205: DB::SelectQueryExpressionAnalyzer::makeJoin(DB::ASTTablesInSelectQueryElement const&, std::vector> const&, std::optional&) @ 0x0000000031ae92b2 7. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:976: DB::SelectQueryExpressionAnalyzer::appendJoin(DB::ExpressionActionsChain&, std::shared_ptr&) @ 0x0000000031ae63bb 8. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2067: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b1494b 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 16. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:56:59.671319 [ 15865 ] {} TCPHandler: Code: 264. DB::Exception: Number of keys in JOIN ON section (4) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x000000001f509a6d 4. ./build_docker/./src/Storages/StorageJoin.cpp:264: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x00000000384ddef8 5. ./build_docker/./src/Storages/StorageJoin.cpp:318: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000384df5af 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1205: DB::SelectQueryExpressionAnalyzer::makeJoin(DB::ASTTablesInSelectQueryElement const&, std::vector> const&, std::optional&) @ 0x0000000031ae92b2 7. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:976: DB::SelectQueryExpressionAnalyzer::appendJoin(DB::ExpressionActionsChain&, std::shared_ptr&) @ 0x0000000031ae63bb 8. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2067: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031b1494b 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1182: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032a5ac3a 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:922: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032a37eca 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a229d5 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 16. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 08:57:00.118549 [ 2137 ] {a816d4bd-ab9e-448f-b968-0585b56d3448} executeQuery: Code: 190. DB::Exception: Lengths of all arrays passed to aggregate function must be equal.: While executing AggregatingTransform. (SIZES_OF_ARRAYS_DONT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52778) (comment: 00534_filimonov.sh) (query 130, line 434) (in query: SELECT uniqUpToArray([CAST( 0 AS Int8)],arrayPopBack([CAST( 0 AS Int8)]));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::checkAndGetNestedArrayOffset(DB::IColumn const**, unsigned long) @ 0x000000002c031db9 5. ./build_docker/./src/Interpreters/Aggregator.cpp:1473: DB::Aggregator::prepareAggregateInstructions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, std::vector>, std::allocator>>>&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector>&, std::vector>, std::allocator>>>&) const @ 0x0000000031bcdade 6. ./build_docker/./src/Interpreters/Aggregator.cpp:1559: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031bd063e 7. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003b9b97c5 8. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003b9ac388 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 08:57:00.139453 [ 2137 ] {} TCPHandler: Code: 190. DB::Exception: Lengths of all arrays passed to aggregate function must be equal.: While executing AggregatingTransform. (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::checkAndGetNestedArrayOffset(DB::IColumn const**, unsigned long) @ 0x000000002c031db9 5. ./build_docker/./src/Interpreters/Aggregator.cpp:1473: DB::Aggregator::prepareAggregateInstructions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, std::vector>, std::allocator>>>&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector>&, std::vector>, std::allocator>>>&) const @ 0x0000000031bcdade 6. ./build_docker/./src/Interpreters/Aggregator.cpp:1559: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031bd063e 7. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003b9b97c5 8. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003b9ac388 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:57:00.221817 [ 2137 ] {fbd05c7c-3f48-433b-883d-7ce79cccd1ad} executeQuery: Code: 190. DB::Exception: Lengths of all arrays passed to aggregate function must be equal.: While executing AggregatingTransform. (SIZES_OF_ARRAYS_DONT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52778) (comment: 00534_filimonov.sh) (query 131, line 435) (in query: SELECT uniqCombinedArray([CAST( 0 AS Int8)],arrayPopBack([CAST( 0 AS Int8)]));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::checkAndGetNestedArrayOffset(DB::IColumn const**, unsigned long) @ 0x000000002c031db9 5. ./build_docker/./src/Interpreters/Aggregator.cpp:1473: DB::Aggregator::prepareAggregateInstructions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, std::vector>, std::allocator>>>&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector>&, std::vector>, std::allocator>>>&) const @ 0x0000000031bcdade 6. ./build_docker/./src/Interpreters/Aggregator.cpp:1559: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031bd063e 7. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003b9b97c5 8. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003b9ac388 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 08:57:00.237299 [ 2137 ] {} TCPHandler: Code: 190. DB::Exception: Lengths of all arrays passed to aggregate function must be equal.: While executing AggregatingTransform. (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::checkAndGetNestedArrayOffset(DB::IColumn const**, unsigned long) @ 0x000000002c031db9 5. ./build_docker/./src/Interpreters/Aggregator.cpp:1473: DB::Aggregator::prepareAggregateInstructions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, std::vector>, std::allocator>>>&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector>&, std::vector>, std::allocator>>>&) const @ 0x0000000031bcdade 6. ./build_docker/./src/Interpreters/Aggregator.cpp:1559: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031bd063e 7. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003b9b97c5 8. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003b9ac388 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:57:00.304761 [ 2137 ] {6e38b024-f284-4ff4-8396-c5cd37bbe862} executeQuery: Code: 46. DB::Exception: Function with name `uniqCombinedBiasCorrectedArray` does not exist. In scope SELECT uniqCombinedBiasCorrectedArray([CAST(0, 'Int8')], arrayPopBack([CAST(0, 'Int8')])). (UNKNOWN_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52778) (comment: 00534_filimonov.sh) (query 132, line 436) (in query: SELECT uniqCombinedBiasCorrectedArray([CAST( 0 AS Int8)],arrayPopBack([CAST( 0 AS Int8)]));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3350: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003038f5f5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:57:00.314719 [ 2137 ] {} TCPHandler: Code: 46. DB::Exception: Function with name `uniqCombinedBiasCorrectedArray` does not exist. In scope SELECT uniqCombinedBiasCorrectedArray([CAST(0, 'Int8')], arrayPopBack([CAST(0, 'Int8')])). (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3350: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003038f5f5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:57:00.362990 [ 2137 ] {4d9ef261-4e03-4a7c-8d37-6cf9deea58be} executeQuery: Code: 46. DB::Exception: Function with name `uniqCombinedLinearCountingArray` does not exist. In scope SELECT uniqCombinedLinearCountingArray([CAST(0, 'Int8')], arrayPopBack([CAST(0, 'Int8')])). (UNKNOWN_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52778) (comment: 00534_filimonov.sh) (query 133, line 437) (in query: SELECT uniqCombinedLinearCountingArray([CAST( 0 AS Int8)],arrayPopBack([CAST( 0 AS Int8)]));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3350: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003038f5f5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:57:00.369802 [ 2137 ] {} TCPHandler: Code: 46. DB::Exception: Function with name `uniqCombinedLinearCountingArray` does not exist. In scope SELECT uniqCombinedLinearCountingArray([CAST(0, 'Int8')], arrayPopBack([CAST(0, 'Int8')])). (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3350: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003038f5f5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:57:00.471793 [ 2137 ] {2154687d-eba4-418c-839b-c983a8435879} executeQuery: Code: 190. DB::Exception: Lengths of all arrays passed to aggregate function must be equal.: While executing AggregatingTransform. (SIZES_OF_ARRAYS_DONT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52778) (comment: 00534_filimonov.sh) (query 134, line 438) (in query: SELECT uniqExactArray([CAST( 0 AS Int8)],arrayPopBack([CAST( 0 AS Int8)]));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::checkAndGetNestedArrayOffset(DB::IColumn const**, unsigned long) @ 0x000000002c031db9 5. ./build_docker/./src/Interpreters/Aggregator.cpp:1473: DB::Aggregator::prepareAggregateInstructions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, std::vector>, std::allocator>>>&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector>&, std::vector>, std::allocator>>>&) const @ 0x0000000031bcdade 6. ./build_docker/./src/Interpreters/Aggregator.cpp:1559: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031bd063e 7. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003b9b97c5 8. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003b9ac388 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 08:57:00.497158 [ 2137 ] {} TCPHandler: Code: 190. DB::Exception: Lengths of all arrays passed to aggregate function must be equal.: While executing AggregatingTransform. (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::checkAndGetNestedArrayOffset(DB::IColumn const**, unsigned long) @ 0x000000002c031db9 5. ./build_docker/./src/Interpreters/Aggregator.cpp:1473: DB::Aggregator::prepareAggregateInstructions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, std::vector>, std::allocator>>>&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector>&, std::vector>, std::allocator>>>&) const @ 0x0000000031bcdade 6. ./build_docker/./src/Interpreters/Aggregator.cpp:1559: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031bd063e 7. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003b9b97c5 8. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003b9ac388 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:57:00.583142 [ 2137 ] {5769214d-4a4f-42a2-bdc9-943b23cff288} executeQuery: Code: 190. DB::Exception: Lengths of all arrays passed to aggregate function must be equal.: While executing AggregatingTransform. (SIZES_OF_ARRAYS_DONT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52778) (comment: 00534_filimonov.sh) (query 135, line 439) (in query: SELECT COVAR_POPArray([CAST( 0 AS Int8)],arrayPopBack([CAST( 0 AS Int8)]));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::checkAndGetNestedArrayOffset(DB::IColumn const**, unsigned long) @ 0x000000002c031db9 5. ./build_docker/./src/Interpreters/Aggregator.cpp:1473: DB::Aggregator::prepareAggregateInstructions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, std::vector>, std::allocator>>>&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector>&, std::vector>, std::allocator>>>&) const @ 0x0000000031bcdade 6. ./build_docker/./src/Interpreters/Aggregator.cpp:1559: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031bd063e 7. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003b9b97c5 8. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003b9ac388 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 08:57:00.611548 [ 2137 ] {} TCPHandler: Code: 190. DB::Exception: Lengths of all arrays passed to aggregate function must be equal.: While executing AggregatingTransform. (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::checkAndGetNestedArrayOffset(DB::IColumn const**, unsigned long) @ 0x000000002c031db9 5. ./build_docker/./src/Interpreters/Aggregator.cpp:1473: DB::Aggregator::prepareAggregateInstructions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, std::vector>, std::allocator>>>&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector>&, std::vector>, std::allocator>>>&) const @ 0x0000000031bcdade 6. ./build_docker/./src/Interpreters/Aggregator.cpp:1559: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031bd063e 7. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003b9b97c5 8. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003b9ac388 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:57:00.755158 [ 2137 ] {4748a394-586f-4af6-9f83-ef4d8c45befa} executeQuery: Code: 190. DB::Exception: Lengths of all arrays passed to aggregate function must be equal.: While executing AggregatingTransform. (SIZES_OF_ARRAYS_DONT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52778) (comment: 00534_filimonov.sh) (query 136, line 440) (in query: SELECT COVAR_SAMPArray([CAST( 0 AS Int8)],arrayPopBack([CAST( 0 AS Int8)]));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::checkAndGetNestedArrayOffset(DB::IColumn const**, unsigned long) @ 0x000000002c031db9 5. ./build_docker/./src/Interpreters/Aggregator.cpp:1473: DB::Aggregator::prepareAggregateInstructions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, std::vector>, std::allocator>>>&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector>&, std::vector>, std::allocator>>>&) const @ 0x0000000031bcdade 6. ./build_docker/./src/Interpreters/Aggregator.cpp:1559: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031bd063e 7. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003b9b97c5 8. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003b9ac388 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 08:57:00.773658 [ 2137 ] {} TCPHandler: Code: 190. DB::Exception: Lengths of all arrays passed to aggregate function must be equal.: While executing AggregatingTransform. (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. DB::checkAndGetNestedArrayOffset(DB::IColumn const**, unsigned long) @ 0x000000002c031db9 5. ./build_docker/./src/Interpreters/Aggregator.cpp:1473: DB::Aggregator::prepareAggregateInstructions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, std::vector>, std::allocator>>>&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector>&, std::vector>, std::allocator>>>&) const @ 0x0000000031bcdade 6. ./build_docker/./src/Interpreters/Aggregator.cpp:1559: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031bd063e 7. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003b9b97c5 8. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003b9ac388 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:57:01.206066 [ 2137 ] {75c346a6-3221-4679-8fff-52b41a770af6} executeQuery: Code: 43. DB::Exception: Second argument (weight) for function quantileTimingWeighted must be unsigned integer, but it has type Int8. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52778) (comment: 00534_filimonov.sh) (query 137, line 441) (in query: SELECT medianTimingWeightedArray([CAST( 0 AS Int8)],arrayPopBack([CAST( 0 AS Int8)]));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, String&&) @ 0x000000000b16ee6d 4. ./src/AggregateFunctions/AggregateFunctionQuantile.h:98: DB::AggregateFunctionQuantile<_BitInt(8), DB::QuantileTiming, DB::NameQuantileTimingWeighted, true, float, false, false>::AggregateFunctionQuantile(std::vector, std::vector::allocator> const&, DB::Array const&) @ 0x00000000222e4c91 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: _ZNSt3__115allocate_sharedB8ne190107IN2DB25AggregateFunctionQuantileIDB8_NS1_14QuantileTimingIS3_EENS1_26NameQuantileTimingWeightedELb1EfLb0ELb0EEENS_9allocatorIS7_EEJRKNS_6vectorINS_10shared_ptrIKNS1_9IDataTypeEEENS8_ISE_EEEERKNS1_5ArrayEETnNS_9enable_ifIXntsr8is_arrayIT_EE5valueEiE4typeELi0EEENSB_ISN_EERKT0_DpOT1_ @ 0x00000000222e3c6f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionQuantile(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000222b3970 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000203d4b63 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d009bfb 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 10. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002d009778 11. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303855f9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 08:57:01.217305 [ 2137 ] {} TCPHandler: Code: 43. DB::Exception: Second argument (weight) for function quantileTimingWeighted must be unsigned integer, but it has type Int8. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, String&&) @ 0x000000000b16ee6d 4. ./src/AggregateFunctions/AggregateFunctionQuantile.h:98: DB::AggregateFunctionQuantile<_BitInt(8), DB::QuantileTiming, DB::NameQuantileTimingWeighted, true, float, false, false>::AggregateFunctionQuantile(std::vector, std::vector::allocator> const&, DB::Array const&) @ 0x00000000222e4c91 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: _ZNSt3__115allocate_sharedB8ne190107IN2DB25AggregateFunctionQuantileIDB8_NS1_14QuantileTimingIS3_EENS1_26NameQuantileTimingWeightedELb1EfLb0ELb0EEENS_9allocatorIS7_EEJRKNS_6vectorINS_10shared_ptrIKNS1_9IDataTypeEEENS8_ISE_EEEERKNS1_5ArrayEETnNS_9enable_ifIXntsr8is_arrayIT_EE5valueEiE4typeELi0EEENSB_ISN_EERKT0_DpOT1_ @ 0x00000000222e3c6f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionQuantile(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000222b3970 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000203d4b63 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d009bfb 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 10. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002d009778 11. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303855f9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 08:57:01.857260 [ 2137 ] {2d207759-1984-4b5f-b3d0-e4a3f48282d3} executeQuery: Code: 42. DB::Exception: Aggregate function for calculation of multiple quantiles require at least one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52778) (comment: 00534_filimonov.sh) (query 138, line 442) (in query: SELECT quantilesDeterministicArray([CAST( 0 AS Int8)],arrayPopBack([CAST( 0 AS Int32)]));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./src/AggregateFunctions/QuantilesCommon.h:47: DB::QuantileLevels::QuantileLevels(DB::Array const&, bool) @ 0x0000000021381f7b 5. ./src/AggregateFunctions/AggregateFunctionQuantile.h:87: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionQuantile(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000214311d0 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000203d4b63 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d009bfb 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002d009778 10. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303855f9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:57:01.864224 [ 2137 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function for calculation of multiple quantiles require at least one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./src/AggregateFunctions/QuantilesCommon.h:47: DB::QuantileLevels::QuantileLevels(DB::Array const&, bool) @ 0x0000000021381f7b 5. ./src/AggregateFunctions/AggregateFunctionQuantile.h:87: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionQuantile(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000214311d0 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000203d4b63 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d009bfb 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002d009778 10. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303855f9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:57:02.295463 [ 2137 ] {e382d8b4-c55e-49d0-9cf5-25e31a7c6e14} executeQuery: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of argument for aggregate function maxIntersections. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52778) (comment: 00534_filimonov.sh) (query 139, line 444) (in query: SELECT maxIntersections([], []);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x00000000208e7837 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionMaxIntersections.cpp:201: DB::(anonymous namespace)::createAggregateFunctionMaxIntersections(DB::(anonymous namespace)::AggregateFunctionIntersectionsKind, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x00000000256ff2d8 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionMaxIntersections.cpp:214: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000256fe9f1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d009bfb 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303855f9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 08:57:02.304962 [ 2137 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of argument for aggregate function maxIntersections. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x00000000208e7837 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionMaxIntersections.cpp:201: DB::(anonymous namespace)::createAggregateFunctionMaxIntersections(DB::(anonymous namespace)::AggregateFunctionIntersectionsKind, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x00000000256ff2d8 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionMaxIntersections.cpp:214: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000256fe9f1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d009bfb 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303855f9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 08:57:02.512256 [ 15861 ] {f8ffe412-1b00-4b2a-9407-a0fb8daabaaf} executeQuery: Code: 344. DB::Exception: Experimental merges with CLEANUP are not allowed. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55044) (comment: 03357_replacing_min_age_cleanup.sh) (query 9, line 28) (in query: OPTIMIZE TABLE t03357_replacing_replicated FINAL CLEANUP;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6135: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000389ea33a 5. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000033858e79 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:57:02.561627 [ 15861 ] {} TCPHandler: Code: 344. DB::Exception: Experimental merges with CLEANUP are not allowed. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6135: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000389ea33a 5. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000033858e79 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 08:57:02.562059 [ 2137 ] {fcbba652-59b3-42c2-b763-b8f363e4e02a} executeQuery: Code: 43. DB::Exception: Illegal type Nothing of argument for aggregate function sum. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52778) (comment: 00534_filimonov.sh) (query 140, line 445) (in query: SELECT sumMap([], []);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a1f836d 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionSum.cpp:66: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionSum(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000023d57266 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000203d4b63 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d009bfb 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002d009778 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303855f9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:57:02.574313 [ 2137 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nothing of argument for aggregate function sum. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a1f836d 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionSum.cpp:66: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionSum(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000023d57266 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000203d4b63 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d009bfb 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002d009778 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303855f9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:57:02.835271 [ 2137 ] {c5d75592-4050-42b7-8fb1-cd58bde593fd} executeQuery: Code: 35. DB::Exception: Array aggregate functions require at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52778) (comment: 00534_filimonov.sh) (query 141, line 447) (in query: SELECT countArray();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionArray.cpp:29: DB::(anonymous namespace)::AggregateFunctionCombinatorArray::transformArguments(std::vector, std::allocator>> const&) const @ 0x0000000026304ea9 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:250: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002d00969b 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303855f9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 29. ? @ 0x00007f5206343ac3 30. ? @ 0x00007f52063d5850 2025.06.13 08:57:02.845353 [ 2137 ] {} TCPHandler: Code: 35. DB::Exception: Array aggregate functions require at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionArray.cpp:29: DB::(anonymous namespace)::AggregateFunctionCombinatorArray::transformArguments(std::vector, std::allocator>> const&) const @ 0x0000000026304ea9 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:250: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002d00969b 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d004f5e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303855f9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 29. ? @ 0x00007f5206343ac3 30. ? @ 0x00007f52063d5850 2025.06.13 08:57:04.872458 [ 15837 ] {32242c5d-b371-4674-ab51-0ecc62f9cf70} executeQuery: Code: 42. DB::Exception: Storage ODBC requires exactly 3 parameters: ODBC('DSN', database or schema, table). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34112) (comment: 01033_storage_odbc_parsing_exception_check.sql) (query 2, line 5) (in query: CREATE TABLE BannerDict (`BannerID` UInt64, `CompaignID` UInt64) ENGINE = ODBC('DSN=pgconn;Database=postgres', bannerdict);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000008bb626d 4. ./build_docker/./src/Storages/StorageXDBC.cpp:188: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107](DB::StorageFactory&, String const&)::'lambda'(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000038db87bd 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:57:04.877319 [ 15837 ] {} TCPHandler: Code: 42. DB::Exception: Storage ODBC requires exactly 3 parameters: ODBC('DSN', database or schema, table). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000008bb626d 4. ./build_docker/./src/Storages/StorageXDBC.cpp:188: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107](DB::StorageFactory&, String const&)::'lambda'(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000038db87bd 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:57:11.927067 [ 15860 ] {ac7b6fb3-1ae4-4c02-987e-cb13c9ae3893} executeQuery: Code: 1. DB::Exception: WITH RECURSIVE is not supported with the old analyzer. Please use `enable_analyzer=1`. (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34206) (comment: 03311_recursive_cte_old_analyzer_error.sql) (query 2, line 3) (in query: WITH RECURSIVE test_table AS ( SELECT 1 AS number UNION ALL SELECT number + 1 FROM test_table WHERE number < 100 ) SELECT sum(number) FROM test_table;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ApplyWithSubqueryVisitor.cpp:56: DB::ApplyWithSubqueryVisitor::visit(DB::ASTSelectQuery&, DB::ApplyWithSubqueryVisitor::Data const&) @ 0x0000000031089553 5. ./build_docker/./src/Interpreters/ApplyWithSubqueryVisitor.cpp:40: DB::ApplyWithSubqueryVisitor::visit(std::shared_ptr&, DB::ApplyWithSubqueryVisitor::Data const&) @ 0x00000000310878bb 6. ./src/Interpreters/ApplyWithSubqueryVisitor.h:26: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a15f22 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 9. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 11. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 2025.06.13 08:57:11.934852 [ 15860 ] {} TCPHandler: Code: 1. DB::Exception: WITH RECURSIVE is not supported with the old analyzer. Please use `enable_analyzer=1`. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ApplyWithSubqueryVisitor.cpp:56: DB::ApplyWithSubqueryVisitor::visit(DB::ASTSelectQuery&, DB::ApplyWithSubqueryVisitor::Data const&) @ 0x0000000031089553 5. ./build_docker/./src/Interpreters/ApplyWithSubqueryVisitor.cpp:40: DB::ApplyWithSubqueryVisitor::visit(std::shared_ptr&, DB::ApplyWithSubqueryVisitor::Data const&) @ 0x00000000310878bb 6. ./src/Interpreters/ApplyWithSubqueryVisitor.h:26: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032a15f22 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:313: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032a14498 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032c936c2 9. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032c8c572 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ca1b8e 11. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:428: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032c9c833 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 2025.06.13 08:57:23.847603 [ 24856 ] {784d6e22-f42c-4bc6-97d7-f600fd1156cd} executeQuery: Code: 321. DB::Exception: Day number 65535 is out of bounds of type DateTime. (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48506) (comment: 03271_date_to_datetime_saturation.sql) (query 10, line 17) (in query: select count() from test where toDateTime(stamp) >= parseDateTimeBestEffort('2024-11-01') settings date_time_overflow_behavior = 'throw';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned short&) @ 0x000000001f5e088a 4. ./src/Functions/FunctionsConversion.h:141: void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::detail::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x000000002cb919f8 5. ./src/Functions/DateTimeTransforms.h:2287: COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x000000002cb91063 6. ./src/Functions/FunctionsConversion.h:1183: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cb6f04a 7. ./src/Core/callOnTypeIndex.h:275: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c7efc4d 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c836ef0 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c835be2 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff69df 15. ./build_docker/./src/Storages/MergeTree/KeyCondition.cpp:972: DB::applyFunction(std::shared_ptr const&, std::shared_ptr const&, DB::FieldRef const&) @ 0x00000000395db05b 16. ./build_docker/./src/Storages/MergeTree/KeyCondition.cpp:2832: DB::KeyCondition::applyMonotonicFunctionsChainToRange(DB::Range, std::vector, std::allocator>> const&, std::shared_ptr, bool) @ 0x00000000395d9339 17. ./build_docker/./src/Storages/MergeTree/KeyCondition.cpp:3134: DB::KeyCondition::checkInHyperrectangle(std::vector> const&, std::vector, std::allocator>> const&, std::unordered_map>, std::hash, std::equal_to, std::allocator>>>> const&) const @ 0x00000000395e6d35 18. ./build_docker/./src/Storages/MergeTree/KeyCondition.cpp:2795: DB::KeyCondition::checkInRange(unsigned long, DB::FieldRef const*, DB::FieldRef const*, std::vector, std::allocator>> const&, BoolMask) const @ 0x00000000395d74f0 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1277: DB::MergeTreeDataSelectExecutor::markRangesFromPKRange(std::shared_ptr const&, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::MarkRanges*, DB::Settings const&, std::shared_ptr)::$_2::operator()(DB::MarkRange const&, BoolMask) const::'lambda'()::operator()() const @ 0x0000000039b591bb 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::markRangesFromPKRange(std::shared_ptr const&, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::MarkRanges*, DB::Settings const&, std::shared_ptr)::$_2::operator()(DB::MarkRange const&, BoolMask) const @ 0x0000000039b4a5f4 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1341: DB::MergeTreeDataSelectExecutor::markRangesFromPKRange(std::shared_ptr const&, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::MarkRanges*, DB::Settings const&, std::shared_ptr) @ 0x0000000039b0e480 22. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:700: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool)::$_0::operator()(unsigned long) const @ 0x0000000039b405e3 23. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:786: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039b38d9b 24. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003c1aa0fb 25. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003c1a5d42 26. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003c1a54d7 27. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:612: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000003c4637a1 28. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:196: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c3befee 29. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f95f8 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 2025.06.13 08:57:23.854953 [ 24856 ] {} TCPHandler: Code: 321. DB::Exception: Day number 65535 is out of bounds of type DateTime. (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned short&) @ 0x000000001f5e088a 4. ./src/Functions/FunctionsConversion.h:141: void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::detail::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x000000002cb919f8 5. ./src/Functions/DateTimeTransforms.h:2287: COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x000000002cb91063 6. ./src/Functions/FunctionsConversion.h:1183: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cb6f04a 7. ./src/Core/callOnTypeIndex.h:275: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c7efc4d 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c836ef0 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c835be2 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff69df 15. ./build_docker/./src/Storages/MergeTree/KeyCondition.cpp:972: DB::applyFunction(std::shared_ptr const&, std::shared_ptr const&, DB::FieldRef const&) @ 0x00000000395db05b 16. ./build_docker/./src/Storages/MergeTree/KeyCondition.cpp:2832: DB::KeyCondition::applyMonotonicFunctionsChainToRange(DB::Range, std::vector, std::allocator>> const&, std::shared_ptr, bool) @ 0x00000000395d9339 17. ./build_docker/./src/Storages/MergeTree/KeyCondition.cpp:3134: DB::KeyCondition::checkInHyperrectangle(std::vector> const&, std::vector, std::allocator>> const&, std::unordered_map>, std::hash, std::equal_to, std::allocator>>>> const&) const @ 0x00000000395e6d35 18. ./build_docker/./src/Storages/MergeTree/KeyCondition.cpp:2795: DB::KeyCondition::checkInRange(unsigned long, DB::FieldRef const*, DB::FieldRef const*, std::vector, std::allocator>> const&, BoolMask) const @ 0x00000000395d74f0 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1277: DB::MergeTreeDataSelectExecutor::markRangesFromPKRange(std::shared_ptr const&, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::MarkRanges*, DB::Settings const&, std::shared_ptr)::$_2::operator()(DB::MarkRange const&, BoolMask) const::'lambda'()::operator()() const @ 0x0000000039b591bb 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::markRangesFromPKRange(std::shared_ptr const&, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::MarkRanges*, DB::Settings const&, std::shared_ptr)::$_2::operator()(DB::MarkRange const&, BoolMask) const @ 0x0000000039b4a5f4 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1341: DB::MergeTreeDataSelectExecutor::markRangesFromPKRange(std::shared_ptr const&, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::MarkRanges*, DB::Settings const&, std::shared_ptr) @ 0x0000000039b0e480 22. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:700: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool)::$_0::operator()(unsigned long) const @ 0x0000000039b405e3 23. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:786: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039b38d9b 24. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003c1aa0fb 25. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003c1a5d42 26. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003c1a54d7 27. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:612: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000003c4637a1 28. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:196: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c3befee 29. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f95f8 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 2025.06.13 08:57:27.509289 [ 24860 ] {a13d2d40-c30c-40d4-8f69-a4cb81183f34} executeQuery: Code: 57. DB::Exception: Table test_606gi189.replica_01108_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55444) (comment: 01108_restart_replicas_rename_deadlock_zookeeper.sh) (query 1, line 1) (in query: RENAME TABLE replica_01108_1_tmp TO replica_01108_2, replica_01108_2_tmp TO replica_01108_3, replica_01108_3_tmp TO replica_01108_4, replica_01108_4_tmp TO replica_01108_1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002e99856a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a098cf 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a015af 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 08:57:27.546223 [ 24860 ] {} TCPHandler: Code: 57. DB::Exception: Table test_606gi189.replica_01108_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002e99856a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a098cf 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a015af 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 08:57:28.697093 [ 24841 ] {7f06e817-22a9-4375-aaae-d34d4c330450} executeQuery: Code: 107. DB::Exception: Cannot open file /var/lib/clickhouse/store/032/03230047-d84d-4b2e-96ca-9330c9265b2f/all_0_1_1/n.bin: , errno: 2, strerror: No such file or directory: (while reading column n): (while reading from part /var/lib/clickhouse/store/032/03230047-d84d-4b2e-96ca-9330c9265b2f/all_0_1_1/ in table test_r82rmeay.rmt1 (03230047-d84d-4b2e-96ca-9330c9265b2f) located on disk default of type local, from mark 0 with max_rows_to_read = 2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (FILE_DOESNT_EXIST) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55494) (comment: 02369_lost_part_intersecting_merges.sh) (query 1, line 1) (in query: select * from rmt1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String&) @ 0x000000001f865f6f 4. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String&) @ 0x000000001f8655e8 5. ./build_docker/./src/IO/ReadBufferFromFile.cpp:48: DB::ReadBufferFromFile::ReadBufferFromFile(String const&, unsigned long, int, char*, unsigned long, std::optional, std::shared_ptr) @ 0x000000001f87bf2a 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long)::$_0::operator()(unsigned long, unsigned long, int) const @ 0x000000002d053433 7. ./build_docker/./src/Disks/IO/createReadBufferFromFileBase.cpp:213: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long) @ 0x000000002d052b2b 8. ./build_docker/./src/Disks/DiskLocal.cpp:343: DB::DiskLocal::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x000000002fd454d5 9. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:131: DB::DataPartStorageOnDiskFull::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x000000003943713e 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderStream.cpp:80: std::unique_ptr> std::__function::__policy_invoker> ()>::__call_impl[abi:ne190107]> ()>>(std::__function::__policy_storage const*) @ 0x0000000039de1fe7 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003dbf5ce3 12. ./src/Compression/CachedCompressedReadBuffer.h:64: non-virtual thunk to DB::CachedCompressedReadBuffer::setReadUntilPosition(unsigned long) @ 0x000000003dbf9f23 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderStream.cpp:188: DB::MergeTreeReaderStream::adjustRightMark(unsigned long) @ 0x0000000039ddcf24 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:327: DB::MergeTreeReaderWide::getStream(bool, DB::ISerialization::SubstreamPath const&, DB::MergeTreeDataPartChecksums const&, DB::NameAndTypePair const&, unsigned long, bool, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&) @ 0x0000000039dea076 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:516: DB::ReadBuffer* std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&)::$_0, DB::ReadBuffer* (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039def773 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f4de465 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039de8146 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039de696b 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039da9bb3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039dc527a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039e2561f 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039e15d8b 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c253bd1 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000039e3e49b 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c200ea7 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 31. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 2025.06.13 08:57:28.721763 [ 24841 ] {} TCPHandler: Code: 107. DB::Exception: Cannot open file /var/lib/clickhouse/store/032/03230047-d84d-4b2e-96ca-9330c9265b2f/all_0_1_1/n.bin: , errno: 2, strerror: No such file or directory: (while reading column n): (while reading from part /var/lib/clickhouse/store/032/03230047-d84d-4b2e-96ca-9330c9265b2f/all_0_1_1/ in table test_r82rmeay.rmt1 (03230047-d84d-4b2e-96ca-9330c9265b2f) located on disk default of type local, from mark 0 with max_rows_to_read = 2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String&) @ 0x000000001f865f6f 4. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String&) @ 0x000000001f8655e8 5. ./build_docker/./src/IO/ReadBufferFromFile.cpp:48: DB::ReadBufferFromFile::ReadBufferFromFile(String const&, unsigned long, int, char*, unsigned long, std::optional, std::shared_ptr) @ 0x000000001f87bf2a 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long)::$_0::operator()(unsigned long, unsigned long, int) const @ 0x000000002d053433 7. ./build_docker/./src/Disks/IO/createReadBufferFromFileBase.cpp:213: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long) @ 0x000000002d052b2b 8. ./build_docker/./src/Disks/DiskLocal.cpp:343: DB::DiskLocal::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x000000002fd454d5 9. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:131: DB::DataPartStorageOnDiskFull::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x000000003943713e 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderStream.cpp:80: std::unique_ptr> std::__function::__policy_invoker> ()>::__call_impl[abi:ne190107]> ()>>(std::__function::__policy_storage const*) @ 0x0000000039de1fe7 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003dbf5ce3 12. ./src/Compression/CachedCompressedReadBuffer.h:64: non-virtual thunk to DB::CachedCompressedReadBuffer::setReadUntilPosition(unsigned long) @ 0x000000003dbf9f23 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderStream.cpp:188: DB::MergeTreeReaderStream::adjustRightMark(unsigned long) @ 0x0000000039ddcf24 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:327: DB::MergeTreeReaderWide::getStream(bool, DB::ISerialization::SubstreamPath const&, DB::MergeTreeDataPartChecksums const&, DB::NameAndTypePair const&, unsigned long, bool, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&) @ 0x0000000039dea076 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:516: DB::ReadBuffer* std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&)::$_0, DB::ReadBuffer* (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039def773 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f4de465 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039de8146 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039de696b 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039da9bb3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039dc527a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039e2561f 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039e15d8b 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c253bd1 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000039e3e49b 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c200ea7 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 31. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:57:28.897311 [ 808 ] {} test_r82rmeay.rmt1 (ReplicatedMergeTreePartCheckThread): ReplicatedCheckResult DB::ReplicatedMergeTreePartCheckThread::checkPartImpl(const String &, bool): Code: 107. DB::ErrnoException: Cannot open file /var/lib/clickhouse/store/032/03230047-d84d-4b2e-96ca-9330c9265b2f/all_0_1_1/columns.txt: , errno: 2, strerror: No such file or directory. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x000000001f83902f 4. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x000000001f838788 5. ./build_docker/./src/IO/OpenedFile.cpp:33: DB::OpenedFile::getFD() const @ 0x000000002d06812d 6. ./src/IO/ReadBufferFromFile.h:101: DB::ReadBufferFromFilePReadWithDescriptorsCache::ReadBufferFromFilePReadWithDescriptorsCache(String const&, unsigned long, int, char*, unsigned long, std::optional, std::shared_ptr) @ 0x000000002d0544c5 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long)::$_0::operator()(unsigned long, unsigned long, int) const @ 0x000000002d052f23 8. ./build_docker/./src/Disks/IO/createReadBufferFromFileBase.cpp:213: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long) @ 0x000000002d052b2b 9. ./build_docker/./src/Disks/DiskLocal.cpp:343: DB::DiskLocal::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x000000002fd454d5 10. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:131: DB::DataPartStorageOnDiskFull::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x000000003943713e 11. ./build_docker/./src/Storages/MergeTree/checkDataPart.cpp:170: DB::checkDataPart(std::shared_ptr, DB::IDataPartStorage const&, DB::NamesAndTypesList const&, DB::MergeTreeDataPartType const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::ReadSettings const&, bool, std::function, bool&, bool) @ 0x000000003a35630a 12. ./build_docker/./src/Storages/MergeTree/checkDataPart.cpp:478: DB::checkDataPart(std::shared_ptr, bool, bool&, std::function, bool) @ 0x000000003a354ac1 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreePartCheckThread.cpp:372: DB::ReplicatedMergeTreePartCheckThread::checkPartImpl(String const&, bool) @ 0x000000003a1974ce 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreePartCheckThread.cpp:451: DB::ReplicatedMergeTreePartCheckThread::checkPartAndFix(String const&, std::optional*, bool) @ 0x000000003a1a03c1 15. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreePartCheckThread.cpp:604: DB::ReplicatedMergeTreePartCheckThread::run() @ 0x000000003a1a7a95 16. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreePartCheckThread.cpp:41: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a1a9b3f 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 18. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 19. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:57:28.898094 [ 808 ] {} test_r82rmeay.rmt1 (ReplicatedMergeTreePartCheckThread): Part all_0_1_1 looks broken. Removing it and will try to fetch. 2025.06.13 08:57:28.917500 [ 808 ] {} test_r82rmeay.rmt1 (ReplicatedMergeTreePartCheckThread): Part all_0_1_1 exists in ZooKeeper and the local part was broken. Detaching it, removing from ZooKeeper and queueing a fetch. 2025.06.13 08:57:29.232048 [ 808 ] {} test_r82rmeay.rmt1 (03230047-d84d-4b2e-96ca-9330c9265b2f): Detached 3 parts covered by broken part all_0_1_1: all_0_1_1, all_0_0_0, all_1_1_0 2025.06.13 08:57:30.140421 [ 15861 ] {0ad7819e-eace-4fbf-8aa8-b44fa279459f} executeQuery: Code: 60. DB::Exception: Table test_606gi189.replica_01108_1_tmp does not exist. Maybe you meant test_606gi189.replica_01108_1?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55546) (comment: 01108_restart_replicas_rename_deadlock_zookeeper.sh) (query 1, line 1) (in query: SYSTEM RESTART REPLICA replica_01108_1_tmp), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:941: DB::InterpreterSystemQuery::doRestartReplica(DB::StorageID const&, std::shared_ptr, bool) @ 0x000000003381a492 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1005: DB::InterpreterSystemQuery::restartReplica(DB::StorageID const&, std::shared_ptr) @ 0x00000000338148c9 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:782: DB::InterpreterSystemQuery::execute() @ 0x00000000337e16a7 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:57:30.148442 [ 15861 ] {} TCPHandler: Code: 60. DB::Exception: Table test_606gi189.replica_01108_1_tmp does not exist. Maybe you meant test_606gi189.replica_01108_1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:941: DB::InterpreterSystemQuery::doRestartReplica(DB::StorageID const&, std::shared_ptr, bool) @ 0x000000003381a492 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1005: DB::InterpreterSystemQuery::restartReplica(DB::StorageID const&, std::shared_ptr) @ 0x00000000338148c9 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:782: DB::InterpreterSystemQuery::execute() @ 0x00000000337e16a7 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:57:31.387367 [ 2137 ] {099564e7-0516-4cdb-a2b0-51dd61dd4b36} executeQuery: Code: 57. DB::Exception: Table test_606gi189.replica_01108_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55648) (comment: 01108_restart_replicas_rename_deadlock_zookeeper.sh) (query 1, line 1) (in query: RENAME TABLE replica_01108_1_tmp TO replica_01108_2, replica_01108_2_tmp TO replica_01108_3, replica_01108_3_tmp TO replica_01108_4, replica_01108_4_tmp TO replica_01108_1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002e99856a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a098cf 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a015af 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 08:57:31.405987 [ 2137 ] {} TCPHandler: Code: 57. DB::Exception: Table test_606gi189.replica_01108_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002e99856a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a098cf 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a015af 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 08:57:32.569200 [ 9234 ] {6f6f2b63-b306-4e31-affa-2e71f2b724d4} executeQuery: Code: 57. DB::Exception: Table test_606gi189.replica_01108_1_tmp already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55702) (comment: 01108_restart_replicas_rename_deadlock_zookeeper.sh) (query 1, line 1) (in query: RENAME TABLE replica_01108_1 TO replica_01108_1_tmp, replica_01108_2 TO replica_01108_2_tmp, replica_01108_3 TO replica_01108_3_tmp, replica_01108_4 TO replica_01108_4_tmp), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002e99856a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a098cf 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a015af 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 08:57:32.580561 [ 9234 ] {} TCPHandler: Code: 57. DB::Exception: Table test_606gi189.replica_01108_1_tmp already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002e99856a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a098cf 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a015af 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 08:57:32.618080 [ 24856 ] {7cb2083a-aea3-41bd-ae2b-b5d2f5c18f0d} executeQuery: Code: 277. DB::Exception: Primary key (stamp) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48506) (comment: 03271_date_to_datetime_saturation.sql) (query 42, line 80) (in query: -- Convert stamp to DateTime (This will overflow and should not use primary key) SELECT count() FROM test WHERE toDateTime(stamp) >= toDateTime(0) SETTINGS force_primary_key = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x00000000384e6aaa 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1754: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003c1a706b 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003c1a5d42 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003c1a54d7 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003c1bc5b8 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1c2fdc 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049298 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 2025.06.13 08:57:32.623481 [ 24856 ] {} TCPHandler: Code: 277. DB::Exception: Primary key (stamp) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x00000000384e6aaa 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1754: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003c1a706b 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003c1a5d42 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003c1a54d7 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003c1bc5b8 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1c2fdc 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c049298 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f9eec 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 2025.06.13 08:57:33.470662 [ 404 ] {8493fdd4-b4f9-43e9-8d26-01088f0011fa} executeQuery: Code: 403. DB::Exception: Cannot determine join keys in JOIN ON expression [Predcates: ()]. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56088) (comment: 01478_not_equi-join_on.sql) (query 1, line 1) (in query: SELECT * FROM (SELECT NULL AS a, 1 AS b) AS foo RIGHT JOIN (SELECT 1024 AS b) AS bar ON 1 = foo.b;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:572: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003c09ee0f 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x000000003c3e710a 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c3be655 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f95f8 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:57:33.484675 [ 404 ] {} TCPHandler: Code: 403. DB::Exception: Cannot determine join keys in JOIN ON expression [Predcates: ()]. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:572: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003c09ee0f 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x000000003c3e710a 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c3be655 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f95f8 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:57:33.685403 [ 404 ] {52361266-9711-4059-927a-bc5212e7598c} executeQuery: Code: 403. DB::Exception: Cannot determine join keys in JOIN ON expression [Predcates: () Right filter: ((equals(1_UInt8, __table3.b)))]. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56088) (comment: 01478_not_equi-join_on.sql) (query 2, line 5) (in query: SELECT * FROM (SELECT NULL AS a, 1 AS b) AS foo RIGHT JOIN (SELECT 1024 AS b) AS bar ON 1 = bar.b;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:572: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003c09ee0f 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x000000003c3e710a 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c3be655 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f95f8 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:57:33.693212 [ 404 ] {} TCPHandler: Code: 403. DB::Exception: Cannot determine join keys in JOIN ON expression [Predcates: () Right filter: ((equals(1_UInt8, __table3.b)))]. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:572: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003c09ee0f 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x000000003c3e710a 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c3be655 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f95f8 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:57:34.425564 [ 3255 ] {81de5434-2d41-4de9-a5bf-3bad0db7f216} executeQuery: Code: 60. DB::Exception: Table test_606gi189.replica_01108_3_tmp does not exist. Maybe you meant test_606gi189.replica_01108_3?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56160) (comment: 01108_restart_replicas_rename_deadlock_zookeeper.sh) (query 1, line 1) (in query: SYSTEM RESTART REPLICA replica_01108_3_tmp), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:941: DB::InterpreterSystemQuery::doRestartReplica(DB::StorageID const&, std::shared_ptr, bool) @ 0x000000003381a492 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1005: DB::InterpreterSystemQuery::restartReplica(DB::StorageID const&, std::shared_ptr) @ 0x00000000338148c9 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:782: DB::InterpreterSystemQuery::execute() @ 0x00000000337e16a7 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:57:34.445967 [ 3255 ] {} TCPHandler: Code: 60. DB::Exception: Table test_606gi189.replica_01108_3_tmp does not exist. Maybe you meant test_606gi189.replica_01108_3?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:941: DB::InterpreterSystemQuery::doRestartReplica(DB::StorageID const&, std::shared_ptr, bool) @ 0x000000003381a492 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1005: DB::InterpreterSystemQuery::restartReplica(DB::StorageID const&, std::shared_ptr) @ 0x00000000338148c9 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:782: DB::InterpreterSystemQuery::execute() @ 0x00000000337e16a7 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:57:38.167019 [ 24843 ] {41f38118-902f-406c-b65d-9ecfaa029b14} executeQuery: Code: 60. DB::Exception: Table test_606gi189.replica_01108_1_tmp does not exist. Maybe you meant test_606gi189.replica_01108_1?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56308) (comment: 01108_restart_replicas_rename_deadlock_zookeeper.sh) (query 1, line 1) (in query: SYSTEM SYNC REPLICA replica_01108_1_tmp), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1282: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x000000003380b4c2 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:763: DB::InterpreterSystemQuery::execute() @ 0x00000000337e4c52 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:57:38.176914 [ 24843 ] {} TCPHandler: Code: 60. DB::Exception: Table test_606gi189.replica_01108_1_tmp does not exist. Maybe you meant test_606gi189.replica_01108_1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1282: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x000000003380b4c2 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:763: DB::InterpreterSystemQuery::execute() @ 0x00000000337e4c52 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:57:39.045307 [ 15838 ] {4187165f-9e82-45c4-a125-4d9d9401de49} executeQuery: Code: 999. DB::Exception: Transaction failed (Node exists): Op #0, path: /test_keeper_map/test_cqbxvipr/test_02706_keeper_map_insert_strict/data/AQAAAAAAAAA=. (KEEPER_EXCEPTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56280) (comment: 02706_keeper_map_insert_strict.sql) (query 9, line 17) (in query: INSERT INTO 02706_keeper_map_insert_strict VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf01a33 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1602: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf02055 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cede6f0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:810: zkutil::ZooKeeper::multi(std::vector, std::allocator>> const&, bool) @ 0x000000003cede439 7. ./build_docker/./src/Storages/StorageKeeperMap.cpp:266: void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()::operator()() const @ 0x0000000038610f75 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop(bool)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop(bool)::'lambda'()>(void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()&&)::'lambda'()>(void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop(bool)::'lambda'()>(void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()&&)::'lambda'()&&) @ 0x000000003860e7ff 9. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: void DB::StorageKeeperMapSink::finalize(bool) @ 0x000000003860e39d 10. ./build_docker/./src/Storages/StorageKeeperMap.cpp:180: DB::StorageKeeperMapSink::onFinish() @ 0x000000003860b1d9 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e76f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d33c 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 17. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b10197a 18. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003adbc219 19. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x000000003ad8e9f8 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:57:39.085386 [ 15838 ] {} TCPHandler: Code: 999. Coordination::Exception: Transaction failed (Node exists): Op #0, path: /test_keeper_map/test_cqbxvipr/test_02706_keeper_map_insert_strict/data/AQAAAAAAAAA=. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf01a33 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1602: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf02055 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cede6f0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:810: zkutil::ZooKeeper::multi(std::vector, std::allocator>> const&, bool) @ 0x000000003cede439 7. ./build_docker/./src/Storages/StorageKeeperMap.cpp:266: void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()::operator()() const @ 0x0000000038610f75 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop(bool)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop(bool)::'lambda'()>(void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()&&)::'lambda'()>(void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop(bool)::'lambda'()>(void DB::StorageKeeperMapSink::finalize(bool)::'lambda'()&&)::'lambda'()&&) @ 0x000000003860e7ff 9. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: void DB::StorageKeeperMapSink::finalize(bool) @ 0x000000003860e39d 10. ./build_docker/./src/Storages/StorageKeeperMap.cpp:180: DB::StorageKeeperMapSink::onFinish() @ 0x000000003860b1d9 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e76f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d33c 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 17. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b10197a 18. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003adbc219 19. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x000000003ad8e9f8 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:57:39.992128 [ 24843 ] {6d6476f1-986d-466f-92e7-da82d97d63bd} executeQuery: Code: 60. DB::Exception: Table test_606gi189.replica_01108_2_tmp does not exist. Maybe you meant test_606gi189.replica_01108_2?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56376) (comment: 01108_restart_replicas_rename_deadlock_zookeeper.sh) (query 1, line 1) (in query: SYSTEM SYNC REPLICA replica_01108_2_tmp), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1282: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x000000003380b4c2 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:763: DB::InterpreterSystemQuery::execute() @ 0x00000000337e4c52 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:57:40.006508 [ 24843 ] {} TCPHandler: Code: 60. DB::Exception: Table test_606gi189.replica_01108_2_tmp does not exist. Maybe you meant test_606gi189.replica_01108_2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1282: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x000000003380b4c2 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:763: DB::InterpreterSystemQuery::execute() @ 0x00000000337e4c52 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:57:41.884823 [ 24872 ] {c29a3853-7eb1-4fbe-b700-6491eda8524d} executeQuery: Code: 60. DB::Exception: Table test_606gi189.replica_01108_3_tmp does not exist. Maybe you meant test_606gi189.replica_01108_3?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56456) (comment: 01108_restart_replicas_rename_deadlock_zookeeper.sh) (query 1, line 1) (in query: SYSTEM SYNC REPLICA replica_01108_3_tmp), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1282: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x000000003380b4c2 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:763: DB::InterpreterSystemQuery::execute() @ 0x00000000337e4c52 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:57:42.096539 [ 24872 ] {} TCPHandler: Code: 60. DB::Exception: Table test_606gi189.replica_01108_3_tmp does not exist. Maybe you meant test_606gi189.replica_01108_3?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1282: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x000000003380b4c2 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:763: DB::InterpreterSystemQuery::execute() @ 0x00000000337e4c52 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:57:43.788533 [ 2138 ] {535a1107-6c2c-45fd-8251-25b922822778} executeQuery: Code: 60. DB::Exception: Table test_606gi189.replica_01108_4_tmp does not exist. Maybe you meant test_606gi189.replica_01108_4?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59836) (comment: 01108_restart_replicas_rename_deadlock_zookeeper.sh) (query 1, line 1) (in query: SYSTEM SYNC REPLICA replica_01108_4_tmp), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1282: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x000000003380b4c2 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:763: DB::InterpreterSystemQuery::execute() @ 0x00000000337e4c52 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:57:43.802995 [ 2138 ] {} TCPHandler: Code: 60. DB::Exception: Table test_606gi189.replica_01108_4_tmp does not exist. Maybe you meant test_606gi189.replica_01108_4?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1282: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x000000003380b4c2 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:763: DB::InterpreterSystemQuery::execute() @ 0x00000000337e4c52 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 08:57:44.874903 [ 9224 ] {da9b12a3-d097-4c41-a726-e2964c43b46e} executeQuery: Code: 42. DB::Exception: Storage S3 requires 1 to 7 arguments. All supported signatures: - url - url, NOSIGN - url, format - url, NOSIGN, format - url, format, structure - url, NOSIGN, format, structure - url, format, structure, compression_method - url, NOSIGN, format, structure, compression_method - url, access_key_id, secret_access_key - url, access_key_id, secret_access_key, session_token - url, access_key_id, secret_access_key, format - url, access_key_id, secret_access_key, session_token, format - url, access_key_id, secret_access_key, format, structure - url, access_key_id, secret_access_key, session_token, format, structure - url, access_key_id, secret_access_key, format, structure, compression_method - url, access_key_id, secret_access_key, session_token, format, structure, compression_method All signatures supports optional headers (specified as `headers('name'='value', 'name2'='value2')`) and extra credentials for role assumption (`extra_credentials(role_arn=value, role_session_name=value)`). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59846) (comment: 02772_s3_crash.sql) (query 1, line 4) (in query: SELECT * FROM s3(headers('random_header' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, String&&) @ 0x00000000173a32cd 4. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:263: DB::StorageS3Configuration::fromAST(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x000000002d55624e 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:616: DB::StorageObjectStorage::Configuration::initialize(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool, std::shared_ptr) @ 0x000000002d31b628 6. ./src/TableFunctions/TableFunctionObjectStorage.h:137: DB::TableFunctionObjectStorage::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x00000000266ee3b8 7. ./build_docker/./src/TableFunctions/TableFunctionObjectStorageClusterFallback.cpp:106: DB::TableFunctionObjectStorageClusterFallback>::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002681feaf 8. ./build_docker/./src/TableFunctions/TableFunctionObjectStorage.cpp:105: DB::TableFunctionObjectStorage::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000266f3413 9. ./src/TableFunctions/ITableFunctionCluster.h:59: DB::ITableFunctionCluster>::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000267e8906 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 08:57:44.896287 [ 9224 ] {} TCPHandler: Code: 42. DB::Exception: Storage S3 requires 1 to 7 arguments. All supported signatures: - url - url, NOSIGN - url, format - url, NOSIGN, format - url, format, structure - url, NOSIGN, format, structure - url, format, structure, compression_method - url, NOSIGN, format, structure, compression_method - url, access_key_id, secret_access_key - url, access_key_id, secret_access_key, session_token - url, access_key_id, secret_access_key, format - url, access_key_id, secret_access_key, session_token, format - url, access_key_id, secret_access_key, format, structure - url, access_key_id, secret_access_key, session_token, format, structure - url, access_key_id, secret_access_key, format, structure, compression_method - url, access_key_id, secret_access_key, session_token, format, structure, compression_method All signatures supports optional headers (specified as `headers('name'='value', 'name2'='value2')`) and extra credentials for role assumption (`extra_credentials(role_arn=value, role_session_name=value)`). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, String&&) @ 0x00000000173a32cd 4. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:263: DB::StorageS3Configuration::fromAST(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x000000002d55624e 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:616: DB::StorageObjectStorage::Configuration::initialize(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool, std::shared_ptr) @ 0x000000002d31b628 6. ./src/TableFunctions/TableFunctionObjectStorage.h:137: DB::TableFunctionObjectStorage::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x00000000266ee3b8 7. ./build_docker/./src/TableFunctions/TableFunctionObjectStorageClusterFallback.cpp:106: DB::TableFunctionObjectStorageClusterFallback>::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002681feaf 8. ./build_docker/./src/TableFunctions/TableFunctionObjectStorage.cpp:105: DB::TableFunctionObjectStorage::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000266f3413 9. ./src/TableFunctions/ITableFunctionCluster.h:59: DB::ITableFunctionCluster>::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000267e8906 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 08:57:45.247087 [ 9224 ] {fe2d9498-eba3-4430-bf40-865d19717ec3} executeQuery: Code: 42. DB::Exception: Storage S3 requires 1 to 7 arguments. All supported signatures: - url - url, NOSIGN - url, format - url, NOSIGN, format - url, format, structure - url, NOSIGN, format, structure - url, format, structure, compression_method - url, NOSIGN, format, structure, compression_method - url, access_key_id, secret_access_key - url, access_key_id, secret_access_key, session_token - url, access_key_id, secret_access_key, format - url, access_key_id, secret_access_key, session_token, format - url, access_key_id, secret_access_key, format, structure - url, access_key_id, secret_access_key, session_token, format, structure - url, access_key_id, secret_access_key, format, structure, compression_method - url, access_key_id, secret_access_key, session_token, format, structure, compression_method All signatures supports optional headers (specified as `headers('name'='value', 'name2'='value2')`) and extra credentials for role assumption (`extra_credentials(role_arn=value, role_session_name=value)`). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59846) (comment: 02772_s3_crash.sql) (query 2, line 5) (in query: SELECT * FROM s3Cluster('test_cluster_two_shards_localhost', headers('random_header' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, String&&) @ 0x00000000173a32cd 4. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:263: DB::StorageS3Configuration::fromAST(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x000000002d55624e 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:616: DB::StorageObjectStorage::Configuration::initialize(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool, std::shared_ptr) @ 0x000000002d31b628 6. ./src/TableFunctions/TableFunctionObjectStorage.h:137: DB::TableFunctionObjectStorage::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x00000000266ee3b8 7. ./src/TableFunctions/ITableFunctionCluster.h:83: DB::ITableFunctionCluster>::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x00000000267eca9f 8. ./build_docker/./src/TableFunctions/TableFunctionObjectStorage.cpp:105: DB::TableFunctionObjectStorage::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000266f3413 9. ./src/TableFunctions/ITableFunctionCluster.h:59: DB::ITableFunctionCluster>::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000267e8906 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 08:57:45.253039 [ 9224 ] {} TCPHandler: Code: 42. DB::Exception: Storage S3 requires 1 to 7 arguments. All supported signatures: - url - url, NOSIGN - url, format - url, NOSIGN, format - url, format, structure - url, NOSIGN, format, structure - url, format, structure, compression_method - url, NOSIGN, format, structure, compression_method - url, access_key_id, secret_access_key - url, access_key_id, secret_access_key, session_token - url, access_key_id, secret_access_key, format - url, access_key_id, secret_access_key, session_token, format - url, access_key_id, secret_access_key, format, structure - url, access_key_id, secret_access_key, session_token, format, structure - url, access_key_id, secret_access_key, format, structure, compression_method - url, access_key_id, secret_access_key, session_token, format, structure, compression_method All signatures supports optional headers (specified as `headers('name'='value', 'name2'='value2')`) and extra credentials for role assumption (`extra_credentials(role_arn=value, role_session_name=value)`). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, String&&) @ 0x00000000173a32cd 4. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:263: DB::StorageS3Configuration::fromAST(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x000000002d55624e 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:616: DB::StorageObjectStorage::Configuration::initialize(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool, std::shared_ptr) @ 0x000000002d31b628 6. ./src/TableFunctions/TableFunctionObjectStorage.h:137: DB::TableFunctionObjectStorage::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x00000000266ee3b8 7. ./src/TableFunctions/ITableFunctionCluster.h:83: DB::ITableFunctionCluster>::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x00000000267eca9f 8. ./build_docker/./src/TableFunctions/TableFunctionObjectStorage.cpp:105: DB::TableFunctionObjectStorage::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000266f3413 9. ./src/TableFunctions/ITableFunctionCluster.h:59: DB::ITableFunctionCluster>::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000267e8906 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 08:58:05.632822 [ 1017 ] {e2055824-a3e0-4328-81bb-3048f3dff25b::all_1_6_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 236. DB::Exception: Cancelled merging parts: While executing MergeTreeSequentialSource. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x000000003968bba7 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1924: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000396d81bf 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000397168b4 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*, DB::Progress const&) @ 0x00000000397165ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f1bb9e3 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e6ab7 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b0f6008 14. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000396c33e0 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000396bdc00 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000396d5401 17. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a471407 18. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 19. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 08:58:08.365376 [ 9228 ] {72971426-9cab-4a0b-9952-7eb826fc36fd} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1008.277431 ms, maximum: 1000 ms. (TIMEOUT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:50688) (comment: 02786_max_execution_time_leaf.sql) (query 2, line 3) (in query: SELECT count() AS `count()` FROM view(SELECT * FROM numbers(100000000000)) AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002f1c10ad 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002f1be243 5. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x0000000032e7ac50 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b0aef87 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae681 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 11. ? @ 0x00007f5206343ac3 12. ? @ 0x00007f52063d5850 2025.06.13 08:58:08.421011 [ 9228 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1008.277431 ms, maximum: 1000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002f1c10ad 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002f1be243 5. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x0000000032e7ac50 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b0aef87 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae681 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 11. ? @ 0x00007f5206343ac3 12. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:58:08.519835 [ 15856 ] {afd9330c-2d9c-4ac3-8852-c3a15eef67f0} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1100.004165 ms, maximum: 1000 ms: While executing NumbersRange. (TIMEOUT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48210) (comment: 02786_max_execution_time_leaf.sql) (query 2, line 3) (in query: SELECT count() FROM cluster('test_cluster_two_shards', view( SELECT * FROM numbers(100000000000) )) SETTINGS max_execution_time_leaf = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002f1c10ad 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002f1be243 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:50: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002f1bb43c 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e6ab7 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:58:08.644460 [ 15856 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1100.004165 ms, maximum: 1000 ms: While executing NumbersRange. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002f1c10ad 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002f1be243 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:50: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002f1bb43c 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e6ab7 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:58:10.393987 [ 15861 ] {266f481d-cfea-48ce-8eff-95f39d95fbe8} executeQuery: Code: 48. DB::Exception: Window functions does not support processing from WithMergeableStateAfterAggregation. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42246) (comment: 01568_window_functions_distributed.sql) (query 13, line 29) (in query: select groupArray(groupArray(number)) over (rows unbounded preceding) as x from remote('127.0.0.{1,2}', '', t_01568) group by mod(number, 3) order by x settings distributed_group_by_no_merge=2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Planner/Planner.cpp:1735: DB::Planner::buildPlanForQueryNode() @ 0x0000000032b0ef31 5. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 6. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 08:58:10.405417 [ 15861 ] {} TCPHandler: Code: 48. DB::Exception: Window functions does not support processing from WithMergeableStateAfterAggregation. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Planner/Planner.cpp:1735: DB::Planner::buildPlanForQueryNode() @ 0x0000000032b0ef31 5. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 6. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 08:58:10.591509 [ 15838 ] {bf70ed31-06c2-406a-8242-d6060c771022} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0) -> throwIf(equals(__table1.number, 1000_UInt16)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48340) (comment: 00602_throw_if.sh) (query 1, line 1) (in query: SELECT throwIf(number = 1000) FROM system.numbers), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:58:10.609976 [ 15838 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0) -> throwIf(equals(__table1.number, 1000_UInt16)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:58:11.612889 [ 15837 ] {c21a657b-67c3-48c1-a4a5-b06371633748} executeQuery: Code: 395. DB::Exception: Number equals 1000: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48362) (comment: 00602_throw_if.sh) (query 1, line 1) (in query: SELECT throwIf(number = 1000, 'Number equals 1000') FROM system.numbers), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::createRuntime(int, String const&) @ 0x000000001a9917fa 3. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98b903 4. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 8. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 9. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 10. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 11. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:58:11.629283 [ 15837 ] {} TCPHandler: Code: 395. DB::Exception: Number equals 1000: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::createRuntime(int, String const&) @ 0x000000001a9917fa 3. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98b903 4. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 8. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 9. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 10. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 11. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:58:12.830092 [ 9237 ] {877e8ddf-e090-4072-9356-b1bae205e1f2} executeQuery: Code: 42. DB::Exception: Number of arguments for function throwIf doesn't match: passed 3, should be 1 or 2: In scope SELECT throwIf(number = 1000, 'Number equals 1000', 1) FROM system.numbers. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48378) (comment: 00602_throw_if.sh) (query 1, line 1) (in query: SELECT throwIf(number = 1000, 'Number equals 1000', 1) FROM system.numbers), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long const&, char const*&&) @ 0x000000001a991997 4. DB::(anonymous namespace)::FunctionThrowIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a98e213 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:58:12.889337 [ 9237 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function throwIf doesn't match: passed 3, should be 1 or 2: In scope SELECT throwIf(number = 1000, 'Number equals 1000', 1) FROM system.numbers. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long const&, char const*&&) @ 0x000000001a991997 4. DB::(anonymous namespace)::FunctionThrowIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a98e213 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:58:14.116286 [ 24843 ] {855c9b58-91d3-48a3-8d78-5616c3337e8f} executeQuery: Code: 43. DB::Exception: Third argument of function throwIf must be Int8, Int16 or Int32 (passed: UInt8): In scope SELECT throwIf(number = 1000, 'Number equals 1000', 1) FROM system.numbers SETTINGS allow_custom_error_code_in_throwif = true. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51614) (comment: 00602_throw_if.sh) (query 1, line 1) (in query: SELECT throwIf(number = 1000, 'Number equals 1000', 1) FROM system.numbers SETTINGS allow_custom_error_code_in_throwif=true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::(anonymous namespace)::FunctionThrowIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a98ea2b 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:58:14.134896 [ 24843 ] {} TCPHandler: Code: 43. DB::Exception: Third argument of function throwIf must be Int8, Int16 or Int32 (passed: UInt8): In scope SELECT throwIf(number = 1000, 'Number equals 1000', 1) FROM system.numbers SETTINGS allow_custom_error_code_in_throwif = true. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::(anonymous namespace)::FunctionThrowIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a98ea2b 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:58:14.351953 [ 24872 ] {d2181b2f-ca35-47b1-b4eb-09c0b1b90ca1} executeQuery: Code: 6. DB::Exception: Cannot parse string 'NULL' as UInt8: syntax error at begin of string. Note: there are toUInt8OrZero and toUInt8OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION CAST(__table1.x :: 3, 'UInt8'_String :: 1) -> CAST(__table1.x, 'UInt8'_String) UInt8 : 0'. (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48414) (comment: 03011_definitive_guide_to_cast.sql) (query 8, line 24) (in query: SELECT CAST(x AS UInt8) AS y, toTypeName(y) FROM VALUES('x Nullable(String)', ('123'), ('NULL'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000008ea7006 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt8, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002c88429c 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c8692c7 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c7e2643 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c7f9f7d 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c7f8ec2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff69df 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c25d2a9 15. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda0'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c7d789f 16. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, std::shared_ptr const&, bool) const::'lambda0'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c7d7504 17. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 21. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 22. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 23. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 24. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 29. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 2025.06.13 08:58:14.391317 [ 24872 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string 'NULL' as UInt8: syntax error at begin of string. Note: there are toUInt8OrZero and toUInt8OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION CAST(__table1.x :: 3, 'UInt8'_String :: 1) -> CAST(__table1.x, 'UInt8'_String) UInt8 : 0'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000008ea7006 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt8, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002c88429c 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c8692c7 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c7e2643 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c7f9f7d 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c7f8ec2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff69df 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c25d2a9 15. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda0'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c7d789f 16. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, std::shared_ptr const&, bool) const::'lambda0'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c7d7504 17. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 21. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 22. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 23. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 24. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 29. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:58:15.173657 [ 24840 ] {1d385c4c-973e-4e06-bea4-e58b5c896abe} executeQuery: Code: 42. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(42_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(42_Int32, 'Int32'_String)) UInt8 : 1'. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51640) (comment: 00602_throw_if.sh) (query 1, line 1) (in query: SELECT throwIf(number = 1000, 'Number equals 1000', toInt32(42)) FROM system.numbers SETTINGS allow_custom_error_code_in_throwif=true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:58:15.202977 [ 24840 ] {} TCPHandler: Code: 42. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(42_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(42_Int32, 'Int32'_String)) UInt8 : 1'. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:58:15.533403 [ 24872 ] {c3c43036-e6ff-4632-827b-f99272cd2998} executeQuery: Code: 72. DB::Exception: Unsigned type must not contain '-' symbol: Cannot parse UInt8 from String: In scope SELECT CAST('-123', 'UInt8'). (CANNOT_PARSE_NUMBER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48414) (comment: 03011_definitive_guide_to_cast.sql) (query 14, line 47) (in query: SELECT CAST('-123' AS UInt8);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./src/IO/ReadHelpers.h:414: void DB::readIntTextImpl(char8_t&, DB::ReadBuffer&) @ 0x000000001f64eb27 5. ./src/IO/ReadHelpers.h:508: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt8, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002c883de4 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c8692c7 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c7e2643 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c7f9f7d 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c7f8ec2 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff69df 15. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c25d2a9 16. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 17. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008bec782 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 19. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 20. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 21. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 22. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 30. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 2025.06.13 08:58:15.540054 [ 24872 ] {} TCPHandler: Code: 72. DB::Exception: Unsigned type must not contain '-' symbol: Cannot parse UInt8 from String: In scope SELECT CAST('-123', 'UInt8'). (CANNOT_PARSE_NUMBER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./src/IO/ReadHelpers.h:414: void DB::readIntTextImpl(char8_t&, DB::ReadBuffer&) @ 0x000000001f64eb27 5. ./src/IO/ReadHelpers.h:508: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt8, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002c883de4 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c8692c7 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c7e2643 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c7f9f7d 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c7f8ec2 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff69df 15. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c25d2a9 16. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 17. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008bec782 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 19. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 20. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 21. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 22. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 30. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 2025.06.13 08:58:15.970840 [ 24872 ] {0b54e136-417a-4284-ae08-9b0661d71a0d} executeQuery: Code: 6. DB::Exception: Cannot parse string ' 123' as UInt8: syntax error at begin of string. Note: there are toUInt8OrZero and toUInt8OrNull functions, which returns zero/NULL instead of throwing exception.: In scope SELECT CAST(' 123', 'UInt8'). (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48414) (comment: 03011_definitive_guide_to_cast.sql) (query 16, line 53) (in query: -- Parsing from a string does not tolerate extra whitespace characters: SELECT CAST(' 123' AS UInt8);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000008ea7006 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt8, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002c88429c 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c8692c7 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c7e2643 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c7f9f7d 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c7f8ec2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff69df 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c25d2a9 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 16. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008bec782 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 18. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 2025.06.13 08:58:15.976794 [ 24872 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string ' 123' as UInt8: syntax error at begin of string. Note: there are toUInt8OrZero and toUInt8OrNull functions, which returns zero/NULL instead of throwing exception.: In scope SELECT CAST(' 123', 'UInt8'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000008ea7006 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt8, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002c88429c 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c8692c7 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c7e2643 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c7f9f7d 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c7f8ec2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff69df 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c25d2a9 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 16. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008bec782 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 18. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 2025.06.13 08:58:16.010635 [ 24872 ] {906b6eea-3336-455e-b954-ec54a6b07db2} executeQuery: Code: 6. DB::Exception: Cannot parse string '123 ' as UInt8: syntax error at position 3 (parsed just '123'). Note: there are toUInt8OrZero and toUInt8OrNull functions, which returns zero/NULL instead of throwing exception.: In scope SELECT CAST('123 ', 'UInt8'). (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48414) (comment: 03011_definitive_guide_to_cast.sql) (query 17, line 56) (in query: SELECT CAST('123 ' AS UInt8);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000008ea7006 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt8, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002c88429c 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c8692c7 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c7e2643 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c7f9f7d 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c7f8ec2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff69df 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c25d2a9 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 16. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008bec782 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 18. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 2025.06.13 08:58:16.016716 [ 24872 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '123 ' as UInt8: syntax error at position 3 (parsed just '123'). Note: there are toUInt8OrZero and toUInt8OrNull functions, which returns zero/NULL instead of throwing exception.: In scope SELECT CAST('123 ', 'UInt8'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000008ea7006 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt8, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002c88429c 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c8692c7 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c7e2643 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c7f9f7d 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c7f8ec2 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff69df 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c25d2a9 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 16. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008bec782 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 18. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 2025.06.13 08:58:16.261120 [ 9224 ] {ab1b88a6-68fb-4669-94c5-a08c75a45109} executeQuery: Code: 0. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(0_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(0_Int32, 'Int32'_String)) UInt8 : 1'. (OK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51680) (comment: 00602_throw_if.sh) (query 1, line 1) (in query: SELECT throwIf(number = 1000, 'Number equals 1000', toInt32(0)) FROM system.numbers SETTINGS allow_custom_error_code_in_throwif=true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:58:16.297466 [ 9224 ] {} TCPHandler: Code: 0. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(0_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(0_Int32, 'Int32'_String)) UInt8 : 1'. (OK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:58:17.299566 [ 24844 ] {f668bd9f-ff1a-4d99-be44-838fbf04a325} executeQuery: Code: 101. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(101_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(101_Int32, 'Int32'_String)) UInt8 : 1'. (UNEXPECTED_PACKET_FROM_CLIENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51688) (comment: 00602_throw_if.sh) (query 1, line 1) (in query: SELECT throwIf(number = 1000, 'Number equals 1000', toInt32(101)) FROM system.numbers SETTINGS allow_custom_error_code_in_throwif=true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:58:17.386349 [ 24844 ] {} TCPHandler: Code: 101. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(101_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(101_Int32, 'Int32'_String)) UInt8 : 1'. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:58:17.562536 [ 24872 ] {2b26a297-d21a-4e79-842f-0bc8dbebd735} executeQuery: Code: 407. DB::Exception: DateTime64 convert overflow. Float is out of Decimal range: In scope SELECT CAST(100000000000000000000., 'DateTime64(9, \'Europe/Amsterdam\')'). (DECIMAL_OVERFLOW) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48414) (comment: 03011_definitive_guide_to_cast.sql) (query 27, line 92) (in query: -- A special case is DateTime64(9) - the maximum resolution, where is does not cover the usual range, -- and in this case, it throws an exception on overflow (I don't mind if we change this behavior in the future): SELECT CAST(1e20 AS DateTime64(9, 'Europe/Amsterdam'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c2574a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDateTime64, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f3ab5ee 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDateTime64>(T::FieldType const&, unsigned int) @ 0x000000002f3b01f5 6. COW::immutable_ptr DB::DateTimeTransformImpl, DB::DataTypeDateTime64, DB::detail::ToDateTime64TransformFloat, double, (DB::FormatSettings::DateTimeOverflowBehavior)0>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::ToDateTime64TransformFloat, double, (DB::FormatSettings::DateTimeOverflowBehavior)0> const&) @ 0x000000002c72c53f 7. bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(T const&)::operator(), DB::DataTypeDateTime64>>(T const&) const @ 0x000000002c71efc6 8. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c71b1b4 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c719564 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008bec782 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 2025.06.13 08:58:17.568475 [ 24872 ] {} TCPHandler: Code: 407. DB::Exception: DateTime64 convert overflow. Float is out of Decimal range: In scope SELECT CAST(100000000000000000000., 'DateTime64(9, \'Europe/Amsterdam\')'). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c2574a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDateTime64, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f3ab5ee 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDateTime64>(T::FieldType const&, unsigned int) @ 0x000000002f3b01f5 6. COW::immutable_ptr DB::DateTimeTransformImpl, DB::DataTypeDateTime64, DB::detail::ToDateTime64TransformFloat, double, (DB::FormatSettings::DateTimeOverflowBehavior)0>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::ToDateTime64TransformFloat, double, (DB::FormatSettings::DateTimeOverflowBehavior)0> const&) @ 0x000000002c72c53f 7. bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(T const&)::operator(), DB::DataTypeDateTime64>>(T const&) const @ 0x000000002c71efc6 8. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c71b1b4 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c719564 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008bec782 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 2025.06.13 08:58:18.288707 [ 24872 ] {2290663f-c3b8-4086-8ef5-5faffd1dadad} executeQuery: Code: 131. DB::Exception: String too long for type FixedString(3): In scope SELECT CAST('12345', 'FixedString(3)'). (TOO_LARGE_STRING_SIZE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48414) (comment: 03011_definitive_guide_to_cast.sql) (query 31, line 110) (in query: -- But if it does not fit, an exception is thrown: SELECT CAST('12345' AS FixedString(3)) FORMAT TSV;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. COW::immutable_ptr DB::FunctionToFixedString::executeForN<(DB::ConvertToFixedStringExceptionMode)0>(std::vector> const&, unsigned long) @ 0x000000001aa3f780 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, unsigned long) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c765988 6. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008bec782 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 2025.06.13 08:58:18.294449 [ 24872 ] {} TCPHandler: Code: 131. DB::Exception: String too long for type FixedString(3): In scope SELECT CAST('12345', 'FixedString(3)'). (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. COW::immutable_ptr DB::FunctionToFixedString::executeForN<(DB::ConvertToFixedStringExceptionMode)0>(std::vector> const&, unsigned long) @ 0x000000001aa3f780 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, unsigned long) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c765988 6. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008bec782 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 2025.06.13 08:58:18.455521 [ 2138 ] {5ac7fa0c-bd37-4993-90d5-673777654e81} executeQuery: Code: 102. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(102_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(102_Int32, 'Int32'_String)) UInt8 : 1'. (UNEXPECTED_PACKET_FROM_SERVER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51716) (comment: 00602_throw_if.sh) (query 1, line 1) (in query: SELECT throwIf(number = 1000, 'Number equals 1000', toInt32(102)) FROM system.numbers SETTINGS allow_custom_error_code_in_throwif=true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:58:18.486031 [ 2138 ] {} TCPHandler: Code: 102. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(102_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(102_Int32, 'Int32'_String)) UInt8 : 1'. (UNEXPECTED_PACKET_FROM_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:58:19.409405 [ 24872 ] {eff6a809-987a-4ba6-977a-b836c0af4904} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `String` in scope SELECT CAST(123, String). (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48414) (comment: 03011_definitive_guide_to_cast.sql) (query 42, line 153) (in query: SELECT CAST(123, String);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000303dd3a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032b465 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:58:19.420525 [ 24872 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `String` in scope SELECT CAST(123, String). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000303dd3a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032b465 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:58:19.499370 [ 15875 ] {8717cfa0-3ca2-49f2-9d4b-3dc847bdff09} executeQuery: Code: 1001. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(1001_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(1001_Int32, 'Int32'_String)) UInt8 : 1'. (STD_EXCEPTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51730) (comment: 00602_throw_if.sh) (query 1, line 1) (in query: SELECT throwIf(number = 1000, 'Number equals 1000', toInt32(1001)) FROM system.numbers SETTINGS allow_custom_error_code_in_throwif=true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:58:19.512240 [ 15875 ] {} TCPHandler: Code: 1001. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(1001_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(1001_Int32, 'Int32'_String)) UInt8 : 1'. (STD_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:58:19.904407 [ 24872 ] {0cb439c6-97bd-4c2e-b5b1-82270715d145} executeQuery: Code: 42. DB::Exception: Number of arguments for function _CAST doesn't match: passed 1, should be 2: In scope SELECT _CAST(123 AS UInt8). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48414) (comment: 03011_definitive_guide_to_cast.sql) (query 45, line 168) (in query: -- There is no operator form of this function: -- does not work, here UInt8 is interpreted as an alias for the value: SELECT _CAST(123 AS UInt8);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8700 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7eb0 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 08:58:19.913107 [ 24872 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function _CAST doesn't match: passed 1, should be 2: In scope SELECT _CAST(123 AS UInt8). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8700 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7eb0 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 08:58:20.557902 [ 15875 ] {904e37f8-c83e-4080-b2da-273692c8b681} executeQuery: Code: 1002. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(1002_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(1002_Int32, 'Int32'_String)) UInt8 : 1'. (UNKNOWN_EXCEPTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51752) (comment: 00602_throw_if.sh) (query 1, line 1) (in query: SELECT throwIf(number = 1000, 'Number equals 1000', toInt32(1002)) FROM system.numbers SETTINGS allow_custom_error_code_in_throwif=true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:58:20.582961 [ 15875 ] {} TCPHandler: Code: 1002. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(1002_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(1002_Int32, 'Int32'_String)) UInt8 : 1'. (UNKNOWN_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:58:20.727222 [ 24872 ] {14879ce1-74b0-4d5e-ace7-06c326ef3e07} executeQuery: Code: 72. DB::Exception: Unsigned type must not contain '-' symbol: Cannot parse UInt64 from String: In scope SELECT CAST('-1', 'UInt64'). (CANNOT_PARSE_NUMBER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48414) (comment: 03011_definitive_guide_to_cast.sql) (query 50, line 190) (in query: -- We can change this behavior in the future. -- Another example: SELECT -1::UInt64;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. void DB::readIntTextImpl(unsigned long&, DB::ReadBuffer&) @ 0x000000000f037eb0 5. ./src/IO/ReadHelpers.h:508: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002c8f6fbe 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c8e20a7 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c7e4a83 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c80477d 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c8036c2 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff69df 15. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c25d2a9 16. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 17. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008bec782 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 19. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 20. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 21. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 22. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 30. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 2025.06.13 08:58:20.733871 [ 24872 ] {} TCPHandler: Code: 72. DB::Exception: Unsigned type must not contain '-' symbol: Cannot parse UInt64 from String: In scope SELECT CAST('-1', 'UInt64'). (CANNOT_PARSE_NUMBER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. void DB::readIntTextImpl(unsigned long&, DB::ReadBuffer&) @ 0x000000000f037eb0 5. ./src/IO/ReadHelpers.h:508: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002c8f6fbe 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c8e20a7 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c7e4a83 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c80477d 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c8036c2 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff69df 15. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c25d2a9 16. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 17. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008bec782 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 19. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 20. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 21. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 22. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 30. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 2025.06.13 08:58:21.541223 [ 24844 ] {1fedf758-799c-45c1-ace7-96c6f8bdd266} executeQuery: Code: 999999. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(999999_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(999999_Int32, 'Int32'_String)) UInt8 : 1'. () (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51778) (comment: 00602_throw_if.sh) (query 1, line 1) (in query: SELECT throwIf(number = 1000, 'Number equals 1000', toInt32(999999)) FROM system.numbers SETTINGS allow_custom_error_code_in_throwif=true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:58:21.563157 [ 24844 ] {} TCPHandler: Code: 999999. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(999999_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(999999_Int32, 'Int32'_String)) UInt8 : 1'. (), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:58:21.684040 [ 24872 ] {05cd2110-6423-47c2-8a53-556c27036d3d} executeQuery: Code: 43. DB::Exception: Illegal types UInt8 and String of arguments of function minus: In scope SELECT 1 - CAST('1', 'String'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48414) (comment: 03011_definitive_guide_to_cast.sql) (query 55, line 210) (in query: -- The operator has the highest priority among others: SELECT 1-1::String;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000014dd0883 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000146da639 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a174126 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:58:21.689866 [ 24872 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types UInt8 and String of arguments of function minus: In scope SELECT 1 - CAST('1', 'String'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000014dd0883 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000146da639 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a174126 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:58:21.846178 [ 24872 ] {e7b20693-1046-489d-a20f-a19a1810982e} executeQuery: Code: 43. DB::Exception: Illegal type String of argument of function negate: In scope SELECT 1 AS x, -CAST(x, 'String'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48414) (comment: 03011_definitive_guide_to_cast.sql) (query 57, line 218) (in query: -- Here it is an operator: SELECT 1 AS x, -x::String;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::FunctionUnaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x00000000173913ab 5. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001735b4e3 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:58:21.860908 [ 24872 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of argument of function negate: In scope SELECT 1 AS x, -CAST(x, 'String'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::FunctionUnaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x00000000173913ab 5. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001735b4e3 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008b9cf06 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 08:58:22.328510 [ 24872 ] {49c11b93-476d-4509-b559-c8a19828d183} executeQuery: Code: 70. DB::Exception: Value in column Float64 cannot be safely converted into type Float32: In scope SELECT accurateCast(1.123456789, 'Float32'). (CANNOT_CONVERT_TYPE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48414) (comment: 03011_definitive_guide_to_cast.sql) (query 58, line 223) (in query: -- 5. Accurate casting functions: `accurateCast`, `accurateCastOrNull`, `accurateCastOrDefault`. -- These functions check if the value is exactly representable in the target data type. -- The function `accurateCast` performs the conversion or throws an exception if the value is not exactly representable: SELECT accurateCast(1.123456789, 'Float32');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeNumber, DB::detail::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, DB::detail::AccurateConvertStrategyAdditions) @ 0x000000002c4dca89 5. bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)::operator(), DB::DataTypeNumber>>(DB::DataTypeNumber const&) const @ 0x000000002c4bf8e1 6. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c4b98cb 7. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c4b9384 8. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 9. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008bec782 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 2025.06.13 08:58:22.338417 [ 24872 ] {} TCPHandler: Code: 70. DB::Exception: Value in column Float64 cannot be safely converted into type Float32: In scope SELECT accurateCast(1.123456789, 'Float32'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeNumber, DB::detail::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, DB::detail::AccurateConvertStrategyAdditions) @ 0x000000002c4dca89 5. bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)::operator(), DB::DataTypeNumber>>(DB::DataTypeNumber const&) const @ 0x000000002c4bf8e1 6. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c4b98cb 7. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c4b9384 8. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 9. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008bec782 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 2025.06.13 08:58:22.593363 [ 15875 ] {671c796a-dcfb-49ff-b4c9-93d75a13a48d} executeQuery: Code: -1. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(-1_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(-1_Int32, 'Int32'_String)) UInt8 : 1'. () (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51808) (comment: 00602_throw_if.sh) (query 1, line 1) (in query: SELECT throwIf(number = 1000, 'Number equals 1000', toInt32(-1)) FROM system.numbers SETTINGS allow_custom_error_code_in_throwif=true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:58:22.619060 [ 15875 ] {} TCPHandler: Code: -1. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(-1_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(-1_Int32, 'Int32'_String)) UInt8 : 1'. (), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 08:58:23.059281 [ 24872 ] {b4260b16-0d7a-4b47-8d6e-fdd0c832eafc} executeQuery: Code: 46. DB::Exception: Function with name `ACCURATECAST` does not exist. In scope SELECT ACCURATECAST(1, 'String'). Maybe you meant: ['accurateCast']. (UNKNOWN_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48414) (comment: 03011_definitive_guide_to_cast.sql) (query 63, line 244) (in query: -- Unfortunately, this does not work as expected: SELECT accurateCastOrDefault(-1, $$Enum8('None' = 1, 'Hello' = 2, 'World' = 3)$$); -- https://github.com/ClickHouse/ClickHouse/issues/61495 -- These functions are case-sensitive, and there are no corresponding operators: SELECT ACCURATECAST(1, 'String');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3350: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003038f5f5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:58:23.068149 [ 24872 ] {} TCPHandler: Code: 46. DB::Exception: Function with name `ACCURATECAST` does not exist. In scope SELECT ACCURATECAST(1, 'String'). Maybe you meant: ['accurateCast']. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3350: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003038f5f5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:58:25.702458 [ 24872 ] {7f66b671-df03-4e39-b37b-39d4256aa96c} executeQuery: Code: 43. DB::Exception: Illegal type UInt8 of first argument of function toUInt8OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt8OrNull(123). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48414) (comment: 03011_definitive_guide_to_cast.sql) (query 81, line 308) (in query: -- These functions are only applicable to string data types. -- Although it is a room for extension: SELECT toUInt8OrNull(123);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./src/Functions/FunctionsConversion.h:2616: DB::detail::FunctionConvertFromString, DB::detail::NameToUInt8OrNull, (DB::detail::ConvertFromStringExceptionMode)2, (DB::detail::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000002ceb88d9 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:58:25.708917 [ 24872 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type UInt8 of first argument of function toUInt8OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt8OrNull(123). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./src/Functions/FunctionsConversion.h:2616: DB::detail::FunctionConvertFromString, DB::detail::NameToUInt8OrNull, (DB::detail::ConvertFromStringExceptionMode)2, (DB::detail::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000002ceb88d9 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:58:35.427897 [ 24856 ] {c22bf7be-c1ec-4116-8507-ee8ff62ae2f6} executeQuery: Code: 1000. DB::Exception: Timeout: connect timed out: 128.0.0.1:8123. (POCO_EXCEPTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34158) (comment: 02044_url_glob_parallel_connection_refused.sh) (query 1, line 1) (in query: SELECT * FROM url('http://128.0.0.{1..10}:8123/?query=SELECT+sleep(1)', TSV, 'x UInt8')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, String const&, int) @ 0x00000000411eb0ac 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:145: Poco::TimeoutException::TimeoutException(String const&, String const&, int) @ 0x00000000411f8cce 2. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:145: Poco::Net::SocketImpl::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x0000000041416ca8 3. ./build_docker/./base/poco/Net/src/StreamSocket.cpp:84: Poco::Net::StreamSocket::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x0000000041422a6e 4. ./build_docker/./base/poco/Net/src/HTTPSession.cpp:227: Poco::Net::HTTPSession::connect(Poco::Net::SocketAddress const&) @ 0x00000000413b4928 5. ./build_docker/./base/poco/Net/src/HTTPClientSession.cpp:471: Poco::Net::HTTPClientSession::reconnect(unsigned long*) @ 0x0000000041374a88 6. ./build_docker/./src/Common/HTTPConnectionPool.cpp:502: DB::EndpointConnectionPool::prepareNewConnection(DB::ConnectionTimeouts const&, unsigned long*) @ 0x0000000020120541 7. ./build_docker/./src/Common/HTTPConnectionPool.cpp:590: DB::EndpointConnectionPool::getConnection(DB::ConnectionTimeouts const&, unsigned long*) @ 0x000000002011d4c5 8. ./build_docker/./src/IO/HTTPCommon.cpp:63: DB::makeHTTPSession(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ConnectionTimeouts const&, DB::ProxyConfiguration const&, unsigned long*) @ 0x0000000020149224 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:267: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002668b22f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000002668b87c 11. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:178: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000002669404d 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 13. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:175: DB::ReadWriteBufferFromHTTP::getHeadResponse(Poco::Net::HTTPResponse&) @ 0x0000000026685d24 14. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:750: DB::ReadWriteBufferFromHTTP::getFileInfo() @ 0x00000000266854d8 15. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:717: DB::ReadWriteBufferFromHTTP::tryGetLastModificationTime() @ 0x0000000026693bde 16. ./build_docker/./src/Storages/StorageURL.cpp:378: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]> ()>>, String const&, std::function>&)>, String const&, std::optional const&, String, std::shared_ptr const&, unsigned long, DB::ConnectionTimeouts const&, DB::CompressionMethod, unsigned long, std::vector> const&, std::vector, std::allocator>> const&, bool, bool)::$_0, bool ()>>(std::__function::__policy_storage const*) @ 0x0000000038d7f8c9 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038d5622e 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:58:35.454502 [ 24856 ] {} TCPHandler: Code: 1000. DB::Exception: Timeout: connect timed out: 128.0.0.1:8123. (POCO_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, String const&, int) @ 0x00000000411eb0ac 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:145: Poco::TimeoutException::TimeoutException(String const&, String const&, int) @ 0x00000000411f8cce 2. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:145: Poco::Net::SocketImpl::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x0000000041416ca8 3. ./build_docker/./base/poco/Net/src/StreamSocket.cpp:84: Poco::Net::StreamSocket::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x0000000041422a6e 4. ./build_docker/./base/poco/Net/src/HTTPSession.cpp:227: Poco::Net::HTTPSession::connect(Poco::Net::SocketAddress const&) @ 0x00000000413b4928 5. ./build_docker/./base/poco/Net/src/HTTPClientSession.cpp:471: Poco::Net::HTTPClientSession::reconnect(unsigned long*) @ 0x0000000041374a88 6. ./build_docker/./src/Common/HTTPConnectionPool.cpp:502: DB::EndpointConnectionPool::prepareNewConnection(DB::ConnectionTimeouts const&, unsigned long*) @ 0x0000000020120541 7. ./build_docker/./src/Common/HTTPConnectionPool.cpp:590: DB::EndpointConnectionPool::getConnection(DB::ConnectionTimeouts const&, unsigned long*) @ 0x000000002011d4c5 8. ./build_docker/./src/IO/HTTPCommon.cpp:63: DB::makeHTTPSession(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ConnectionTimeouts const&, DB::ProxyConfiguration const&, unsigned long*) @ 0x0000000020149224 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:267: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002668b22f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000002668b87c 11. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:178: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000002669404d 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 13. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:175: DB::ReadWriteBufferFromHTTP::getHeadResponse(Poco::Net::HTTPResponse&) @ 0x0000000026685d24 14. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:750: DB::ReadWriteBufferFromHTTP::getFileInfo() @ 0x00000000266854d8 15. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:717: DB::ReadWriteBufferFromHTTP::tryGetLastModificationTime() @ 0x0000000026693bde 16. ./build_docker/./src/Storages/StorageURL.cpp:378: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]> ()>>, String const&, std::function>&)>, String const&, std::optional const&, String, std::shared_ptr const&, unsigned long, DB::ConnectionTimeouts const&, DB::CompressionMethod, unsigned long, std::vector> const&, std::vector, std::allocator>> const&, bool, bool)::$_0, bool ()>>(std::__function::__policy_storage const*) @ 0x0000000038d7f8c9 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038d5622e 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:58:38.433590 [ 15856 ] {750193e1-69eb-4103-b1f5-43df9f0ca4ba} executeQuery: Code: 1000. DB::Exception: Timeout: connect timed out: 128.0.0.1:8123. (POCO_EXCEPTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38540) (comment: 02044_url_glob_parallel_connection_refused.sh) (query 1, line 1) (in query: SELECT * FROM url('http://128.0.0.{1..10}:8123/?query=SELECT+sleep(1)', TSV, 'x UInt8')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, String const&, int) @ 0x00000000411eb0ac 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:145: Poco::TimeoutException::TimeoutException(String const&, String const&, int) @ 0x00000000411f8cce 2. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:145: Poco::Net::SocketImpl::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x0000000041416ca8 3. ./build_docker/./base/poco/Net/src/StreamSocket.cpp:84: Poco::Net::StreamSocket::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x0000000041422a6e 4. ./build_docker/./base/poco/Net/src/HTTPSession.cpp:227: Poco::Net::HTTPSession::connect(Poco::Net::SocketAddress const&) @ 0x00000000413b4928 5. ./build_docker/./base/poco/Net/src/HTTPClientSession.cpp:471: Poco::Net::HTTPClientSession::reconnect(unsigned long*) @ 0x0000000041374a88 6. ./build_docker/./src/Common/HTTPConnectionPool.cpp:502: DB::EndpointConnectionPool::prepareNewConnection(DB::ConnectionTimeouts const&, unsigned long*) @ 0x0000000020120541 7. ./build_docker/./src/Common/HTTPConnectionPool.cpp:590: DB::EndpointConnectionPool::getConnection(DB::ConnectionTimeouts const&, unsigned long*) @ 0x000000002011d4c5 8. ./build_docker/./src/IO/HTTPCommon.cpp:63: DB::makeHTTPSession(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ConnectionTimeouts const&, DB::ProxyConfiguration const&, unsigned long*) @ 0x0000000020149224 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:267: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002668b22f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000002668b87c 11. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:178: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000002669404d 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 13. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:175: DB::ReadWriteBufferFromHTTP::getHeadResponse(Poco::Net::HTTPResponse&) @ 0x0000000026685d24 14. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:750: DB::ReadWriteBufferFromHTTP::getFileInfo() @ 0x00000000266854d8 15. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:717: DB::ReadWriteBufferFromHTTP::tryGetLastModificationTime() @ 0x0000000026693bde 16. ./build_docker/./src/Storages/StorageURL.cpp:378: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]> ()>>, String const&, std::function>&)>, String const&, std::optional const&, String, std::shared_ptr const&, unsigned long, DB::ConnectionTimeouts const&, DB::CompressionMethod, unsigned long, std::vector> const&, std::vector, std::allocator>> const&, bool, bool)::$_0, bool ()>>(std::__function::__policy_storage const*) @ 0x0000000038d7f8c9 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038d5622e 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:58:38.455600 [ 15856 ] {} TCPHandler: Code: 1000. DB::Exception: Timeout: connect timed out: 128.0.0.1:8123. (POCO_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, String const&, int) @ 0x00000000411eb0ac 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:145: Poco::TimeoutException::TimeoutException(String const&, String const&, int) @ 0x00000000411f8cce 2. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:145: Poco::Net::SocketImpl::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x0000000041416ca8 3. ./build_docker/./base/poco/Net/src/StreamSocket.cpp:84: Poco::Net::StreamSocket::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x0000000041422a6e 4. ./build_docker/./base/poco/Net/src/HTTPSession.cpp:227: Poco::Net::HTTPSession::connect(Poco::Net::SocketAddress const&) @ 0x00000000413b4928 5. ./build_docker/./base/poco/Net/src/HTTPClientSession.cpp:471: Poco::Net::HTTPClientSession::reconnect(unsigned long*) @ 0x0000000041374a88 6. ./build_docker/./src/Common/HTTPConnectionPool.cpp:502: DB::EndpointConnectionPool::prepareNewConnection(DB::ConnectionTimeouts const&, unsigned long*) @ 0x0000000020120541 7. ./build_docker/./src/Common/HTTPConnectionPool.cpp:590: DB::EndpointConnectionPool::getConnection(DB::ConnectionTimeouts const&, unsigned long*) @ 0x000000002011d4c5 8. ./build_docker/./src/IO/HTTPCommon.cpp:63: DB::makeHTTPSession(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ConnectionTimeouts const&, DB::ProxyConfiguration const&, unsigned long*) @ 0x0000000020149224 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:267: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002668b22f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000002668b87c 11. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:178: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000002669404d 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 13. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:175: DB::ReadWriteBufferFromHTTP::getHeadResponse(Poco::Net::HTTPResponse&) @ 0x0000000026685d24 14. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:750: DB::ReadWriteBufferFromHTTP::getFileInfo() @ 0x00000000266854d8 15. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:717: DB::ReadWriteBufferFromHTTP::tryGetLastModificationTime() @ 0x0000000026693bde 16. ./build_docker/./src/Storages/StorageURL.cpp:378: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]> ()>>, String const&, std::function>&)>, String const&, std::optional const&, String, std::shared_ptr const&, unsigned long, DB::ConnectionTimeouts const&, DB::CompressionMethod, unsigned long, std::vector> const&, std::vector, std::allocator>> const&, bool, bool)::$_0, bool ()>>(std::__function::__policy_storage const*) @ 0x0000000038d7f8c9 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038d5622e 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:58:41.456377 [ 24841 ] {c8c7aa9d-0a22-4b54-bd95-25725bf22cd8} executeQuery: Code: 1000. DB::Exception: Timeout: connect timed out: 128.0.0.1:8123. (POCO_EXCEPTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38600) (comment: 02044_url_glob_parallel_connection_refused.sh) (query 1, line 1) (in query: SELECT * FROM url('http://128.0.0.{1..10}:8123/?query=SELECT+sleep(1)', TSV, 'x UInt8')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, String const&, int) @ 0x00000000411eb0ac 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:145: Poco::TimeoutException::TimeoutException(String const&, String const&, int) @ 0x00000000411f8cce 2. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:145: Poco::Net::SocketImpl::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x0000000041416ca8 3. ./build_docker/./base/poco/Net/src/StreamSocket.cpp:84: Poco::Net::StreamSocket::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x0000000041422a6e 4. ./build_docker/./base/poco/Net/src/HTTPSession.cpp:227: Poco::Net::HTTPSession::connect(Poco::Net::SocketAddress const&) @ 0x00000000413b4928 5. ./build_docker/./base/poco/Net/src/HTTPClientSession.cpp:471: Poco::Net::HTTPClientSession::reconnect(unsigned long*) @ 0x0000000041374a88 6. ./build_docker/./src/Common/HTTPConnectionPool.cpp:502: DB::EndpointConnectionPool::prepareNewConnection(DB::ConnectionTimeouts const&, unsigned long*) @ 0x0000000020120541 7. ./build_docker/./src/Common/HTTPConnectionPool.cpp:590: DB::EndpointConnectionPool::getConnection(DB::ConnectionTimeouts const&, unsigned long*) @ 0x000000002011d4c5 8. ./build_docker/./src/IO/HTTPCommon.cpp:63: DB::makeHTTPSession(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ConnectionTimeouts const&, DB::ProxyConfiguration const&, unsigned long*) @ 0x0000000020149224 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:267: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002668b22f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000002668b87c 11. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:178: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000002669404d 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 13. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:175: DB::ReadWriteBufferFromHTTP::getHeadResponse(Poco::Net::HTTPResponse&) @ 0x0000000026685d24 14. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:750: DB::ReadWriteBufferFromHTTP::getFileInfo() @ 0x00000000266854d8 15. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:717: DB::ReadWriteBufferFromHTTP::tryGetLastModificationTime() @ 0x0000000026693bde 16. ./build_docker/./src/Storages/StorageURL.cpp:378: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]> ()>>, String const&, std::function>&)>, String const&, std::optional const&, String, std::shared_ptr const&, unsigned long, DB::ConnectionTimeouts const&, DB::CompressionMethod, unsigned long, std::vector> const&, std::vector, std::allocator>> const&, bool, bool)::$_0, bool ()>>(std::__function::__policy_storage const*) @ 0x0000000038d7f8c9 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038d5622e 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:58:41.481274 [ 24841 ] {} TCPHandler: Code: 1000. DB::Exception: Timeout: connect timed out: 128.0.0.1:8123. (POCO_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, String const&, int) @ 0x00000000411eb0ac 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:145: Poco::TimeoutException::TimeoutException(String const&, String const&, int) @ 0x00000000411f8cce 2. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:145: Poco::Net::SocketImpl::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x0000000041416ca8 3. ./build_docker/./base/poco/Net/src/StreamSocket.cpp:84: Poco::Net::StreamSocket::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x0000000041422a6e 4. ./build_docker/./base/poco/Net/src/HTTPSession.cpp:227: Poco::Net::HTTPSession::connect(Poco::Net::SocketAddress const&) @ 0x00000000413b4928 5. ./build_docker/./base/poco/Net/src/HTTPClientSession.cpp:471: Poco::Net::HTTPClientSession::reconnect(unsigned long*) @ 0x0000000041374a88 6. ./build_docker/./src/Common/HTTPConnectionPool.cpp:502: DB::EndpointConnectionPool::prepareNewConnection(DB::ConnectionTimeouts const&, unsigned long*) @ 0x0000000020120541 7. ./build_docker/./src/Common/HTTPConnectionPool.cpp:590: DB::EndpointConnectionPool::getConnection(DB::ConnectionTimeouts const&, unsigned long*) @ 0x000000002011d4c5 8. ./build_docker/./src/IO/HTTPCommon.cpp:63: DB::makeHTTPSession(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ConnectionTimeouts const&, DB::ProxyConfiguration const&, unsigned long*) @ 0x0000000020149224 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:267: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002668b22f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000002668b87c 11. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:178: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000002669404d 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 13. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:175: DB::ReadWriteBufferFromHTTP::getHeadResponse(Poco::Net::HTTPResponse&) @ 0x0000000026685d24 14. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:750: DB::ReadWriteBufferFromHTTP::getFileInfo() @ 0x00000000266854d8 15. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:717: DB::ReadWriteBufferFromHTTP::tryGetLastModificationTime() @ 0x0000000026693bde 16. ./build_docker/./src/Storages/StorageURL.cpp:378: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]> ()>>, String const&, std::function>&)>, String const&, std::optional const&, String, std::shared_ptr const&, unsigned long, DB::ConnectionTimeouts const&, DB::CompressionMethod, unsigned long, std::vector> const&, std::vector, std::allocator>> const&, bool, bool)::$_0, bool ()>>(std::__function::__policy_storage const*) @ 0x0000000038d7f8c9 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038d5622e 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:58:44.567437 [ 24843 ] {83efc83d-1bb9-44ce-b343-a9539ec05089} executeQuery: Code: 1000. DB::Exception: Timeout: connect timed out: 128.0.0.1:8123. (POCO_EXCEPTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38664) (comment: 02044_url_glob_parallel_connection_refused.sh) (query 1, line 1) (in query: SELECT * FROM url('http://128.0.0.{1..10}:8123/?query=SELECT+sleep(1)', TSV, 'x UInt8')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, String const&, int) @ 0x00000000411eb0ac 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:145: Poco::TimeoutException::TimeoutException(String const&, String const&, int) @ 0x00000000411f8cce 2. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:145: Poco::Net::SocketImpl::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x0000000041416ca8 3. ./build_docker/./base/poco/Net/src/StreamSocket.cpp:84: Poco::Net::StreamSocket::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x0000000041422a6e 4. ./build_docker/./base/poco/Net/src/HTTPSession.cpp:227: Poco::Net::HTTPSession::connect(Poco::Net::SocketAddress const&) @ 0x00000000413b4928 5. ./build_docker/./base/poco/Net/src/HTTPClientSession.cpp:471: Poco::Net::HTTPClientSession::reconnect(unsigned long*) @ 0x0000000041374a88 6. ./build_docker/./src/Common/HTTPConnectionPool.cpp:502: DB::EndpointConnectionPool::prepareNewConnection(DB::ConnectionTimeouts const&, unsigned long*) @ 0x0000000020120541 7. ./build_docker/./src/Common/HTTPConnectionPool.cpp:590: DB::EndpointConnectionPool::getConnection(DB::ConnectionTimeouts const&, unsigned long*) @ 0x000000002011d4c5 8. ./build_docker/./src/IO/HTTPCommon.cpp:63: DB::makeHTTPSession(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ConnectionTimeouts const&, DB::ProxyConfiguration const&, unsigned long*) @ 0x0000000020149224 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:267: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002668b22f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000002668b87c 11. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:178: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000002669404d 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 13. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:175: DB::ReadWriteBufferFromHTTP::getHeadResponse(Poco::Net::HTTPResponse&) @ 0x0000000026685d24 14. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:750: DB::ReadWriteBufferFromHTTP::getFileInfo() @ 0x00000000266854d8 15. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:717: DB::ReadWriteBufferFromHTTP::tryGetLastModificationTime() @ 0x0000000026693bde 16. ./build_docker/./src/Storages/StorageURL.cpp:378: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]> ()>>, String const&, std::function>&)>, String const&, std::optional const&, String, std::shared_ptr const&, unsigned long, DB::ConnectionTimeouts const&, DB::CompressionMethod, unsigned long, std::vector> const&, std::vector, std::allocator>> const&, bool, bool)::$_0, bool ()>>(std::__function::__policy_storage const*) @ 0x0000000038d7f8c9 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038d5622e 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:58:44.596975 [ 24843 ] {} TCPHandler: Code: 1000. DB::Exception: Timeout: connect timed out: 128.0.0.1:8123. (POCO_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, String const&, int) @ 0x00000000411eb0ac 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:145: Poco::TimeoutException::TimeoutException(String const&, String const&, int) @ 0x00000000411f8cce 2. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:145: Poco::Net::SocketImpl::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x0000000041416ca8 3. ./build_docker/./base/poco/Net/src/StreamSocket.cpp:84: Poco::Net::StreamSocket::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x0000000041422a6e 4. ./build_docker/./base/poco/Net/src/HTTPSession.cpp:227: Poco::Net::HTTPSession::connect(Poco::Net::SocketAddress const&) @ 0x00000000413b4928 5. ./build_docker/./base/poco/Net/src/HTTPClientSession.cpp:471: Poco::Net::HTTPClientSession::reconnect(unsigned long*) @ 0x0000000041374a88 6. ./build_docker/./src/Common/HTTPConnectionPool.cpp:502: DB::EndpointConnectionPool::prepareNewConnection(DB::ConnectionTimeouts const&, unsigned long*) @ 0x0000000020120541 7. ./build_docker/./src/Common/HTTPConnectionPool.cpp:590: DB::EndpointConnectionPool::getConnection(DB::ConnectionTimeouts const&, unsigned long*) @ 0x000000002011d4c5 8. ./build_docker/./src/IO/HTTPCommon.cpp:63: DB::makeHTTPSession(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ConnectionTimeouts const&, DB::ProxyConfiguration const&, unsigned long*) @ 0x0000000020149224 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:267: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002668b22f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000002668b87c 11. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:178: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000002669404d 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 13. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:175: DB::ReadWriteBufferFromHTTP::getHeadResponse(Poco::Net::HTTPResponse&) @ 0x0000000026685d24 14. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:750: DB::ReadWriteBufferFromHTTP::getFileInfo() @ 0x00000000266854d8 15. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:717: DB::ReadWriteBufferFromHTTP::tryGetLastModificationTime() @ 0x0000000026693bde 16. ./build_docker/./src/Storages/StorageURL.cpp:378: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]> ()>>, String const&, std::function>&)>, String const&, std::optional const&, String, std::shared_ptr const&, unsigned long, DB::ConnectionTimeouts const&, DB::CompressionMethod, unsigned long, std::vector> const&, std::vector, std::allocator>> const&, bool, bool)::$_0, bool ()>>(std::__function::__policy_storage const*) @ 0x0000000038d7f8c9 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038d5622e 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:58:47.651522 [ 9224 ] {3eb7eac0-ba1f-4819-bada-3fa59294b418} executeQuery: Code: 1000. DB::Exception: Timeout: connect timed out: 128.0.0.1:8123. (POCO_EXCEPTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33186) (comment: 02044_url_glob_parallel_connection_refused.sh) (query 1, line 1) (in query: SELECT * FROM url('http://128.0.0.{1..10}:8123/?query=SELECT+sleep(1)', TSV, 'x UInt8')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, String const&, int) @ 0x00000000411eb0ac 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:145: Poco::TimeoutException::TimeoutException(String const&, String const&, int) @ 0x00000000411f8cce 2. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:145: Poco::Net::SocketImpl::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x0000000041416ca8 3. ./build_docker/./base/poco/Net/src/StreamSocket.cpp:84: Poco::Net::StreamSocket::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x0000000041422a6e 4. ./build_docker/./base/poco/Net/src/HTTPSession.cpp:227: Poco::Net::HTTPSession::connect(Poco::Net::SocketAddress const&) @ 0x00000000413b4928 5. ./build_docker/./base/poco/Net/src/HTTPClientSession.cpp:471: Poco::Net::HTTPClientSession::reconnect(unsigned long*) @ 0x0000000041374a88 6. ./build_docker/./src/Common/HTTPConnectionPool.cpp:502: DB::EndpointConnectionPool::prepareNewConnection(DB::ConnectionTimeouts const&, unsigned long*) @ 0x0000000020120541 7. ./build_docker/./src/Common/HTTPConnectionPool.cpp:590: DB::EndpointConnectionPool::getConnection(DB::ConnectionTimeouts const&, unsigned long*) @ 0x000000002011d4c5 8. ./build_docker/./src/IO/HTTPCommon.cpp:63: DB::makeHTTPSession(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ConnectionTimeouts const&, DB::ProxyConfiguration const&, unsigned long*) @ 0x0000000020149224 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:267: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002668b22f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000002668b87c 11. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:178: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000002669404d 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 13. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:175: DB::ReadWriteBufferFromHTTP::getHeadResponse(Poco::Net::HTTPResponse&) @ 0x0000000026685d24 14. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:750: DB::ReadWriteBufferFromHTTP::getFileInfo() @ 0x00000000266854d8 15. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:717: DB::ReadWriteBufferFromHTTP::tryGetLastModificationTime() @ 0x0000000026693bde 16. ./build_docker/./src/Storages/StorageURL.cpp:378: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]> ()>>, String const&, std::function>&)>, String const&, std::optional const&, String, std::shared_ptr const&, unsigned long, DB::ConnectionTimeouts const&, DB::CompressionMethod, unsigned long, std::vector> const&, std::vector, std::allocator>> const&, bool, bool)::$_0, bool ()>>(std::__function::__policy_storage const*) @ 0x0000000038d7f8c9 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038d5622e 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:58:47.685214 [ 9224 ] {} TCPHandler: Code: 1000. DB::Exception: Timeout: connect timed out: 128.0.0.1:8123. (POCO_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, String const&, int) @ 0x00000000411eb0ac 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:145: Poco::TimeoutException::TimeoutException(String const&, String const&, int) @ 0x00000000411f8cce 2. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:145: Poco::Net::SocketImpl::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x0000000041416ca8 3. ./build_docker/./base/poco/Net/src/StreamSocket.cpp:84: Poco::Net::StreamSocket::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x0000000041422a6e 4. ./build_docker/./base/poco/Net/src/HTTPSession.cpp:227: Poco::Net::HTTPSession::connect(Poco::Net::SocketAddress const&) @ 0x00000000413b4928 5. ./build_docker/./base/poco/Net/src/HTTPClientSession.cpp:471: Poco::Net::HTTPClientSession::reconnect(unsigned long*) @ 0x0000000041374a88 6. ./build_docker/./src/Common/HTTPConnectionPool.cpp:502: DB::EndpointConnectionPool::prepareNewConnection(DB::ConnectionTimeouts const&, unsigned long*) @ 0x0000000020120541 7. ./build_docker/./src/Common/HTTPConnectionPool.cpp:590: DB::EndpointConnectionPool::getConnection(DB::ConnectionTimeouts const&, unsigned long*) @ 0x000000002011d4c5 8. ./build_docker/./src/IO/HTTPCommon.cpp:63: DB::makeHTTPSession(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ConnectionTimeouts const&, DB::ProxyConfiguration const&, unsigned long*) @ 0x0000000020149224 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:267: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002668b22f 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000002668b87c 11. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:178: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000002669404d 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 13. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:175: DB::ReadWriteBufferFromHTTP::getHeadResponse(Poco::Net::HTTPResponse&) @ 0x0000000026685d24 14. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:750: DB::ReadWriteBufferFromHTTP::getFileInfo() @ 0x00000000266854d8 15. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:717: DB::ReadWriteBufferFromHTTP::tryGetLastModificationTime() @ 0x0000000026693bde 16. ./build_docker/./src/Storages/StorageURL.cpp:378: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]> ()>>, String const&, std::function>&)>, String const&, std::optional const&, String, std::shared_ptr const&, unsigned long, DB::ConnectionTimeouts const&, DB::CompressionMethod, unsigned long, std::vector> const&, std::vector, std::allocator>> const&, bool, bool)::$_0, bool ()>>(std::__function::__policy_storage const*) @ 0x0000000038d7f8c9 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000038d5622e 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:59:04.406217 [ 24841 ] {53288a08-820c-4008-81fe-4b08ba25bc2e} executeQuery: Code: 703. DB::Exception: Expected identifier 't.t.t' to contain 1 or 2 parts to be resolved as table expression. In scope system.tables. (INVALID_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36968) (comment: 02963_invalid_identifier.sql) (query 1, line 1) (in query: SELECT t.t.t.* FROM system.tables WHERE database = currentDatabase();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:662: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000031033967 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1349: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000310367a3 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000031044302 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b991 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1877: DB::QueryAnalyzer::resolveQualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003036c4f3 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2204: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303a177a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3800: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030327a79 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:59:04.418084 [ 24841 ] {} TCPHandler: Code: 703. DB::Exception: Expected identifier 't.t.t' to contain 1 or 2 parts to be resolved as table expression. In scope system.tables. (INVALID_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:662: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000031033967 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1349: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000310367a3 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000031044302 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b991 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1877: DB::QueryAnalyzer::resolveQualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003036c4f3 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2204: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303a177a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3800: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030327a79 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:59:10.400622 [ 15867 ] {7045fca6-f966-4fa7-ac5f-0b16773b5183} executeQuery: Code: 36. DB::Exception: Invalid arguments, key_value_delimiter conflicts with pair delimiters: In scope WITH extractKeyValuePairs('not_important', ':', ',:', '\'') AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36960) (comment: 02499_extract_key_value_pairs_multiple_input.sql) (query 23, line 294) (in query: -- { echoOff } -- cross parameter validation tests -- should fail because key value delimiter conflicts with pair delimiters WITH extractKeyValuePairs('not_important', ':', ',:', '\'') AS s_map, CAST( arrayMap( (x) -> (x, s_map[x]), arraySort(mapKeys(s_map)) ), 'Map(String,String)' ) AS x SELECT x;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Functions/keyvaluepair/impl/Configuration.cpp:69: DB::extractKV::ConfigurationFactory::validate(char, char, std::vector>) @ 0x000000001f537056 5. ./build_docker/./src/Functions/keyvaluepair/impl/Configuration.cpp:23: DB::extractKV::ConfigurationFactory::createWithoutEscaping(char, char, std::vector>) @ 0x000000001f5366e9 6. ./src/Functions/keyvaluepair/impl/KeyValuePairExtractorBuilder.h:27: DB::KeyValuePairExtractorBuilder::buildWithoutEscaping() const @ 0x000000001f5244a6 7. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:59: DB::ExtractKeyValuePairs::getExtractor(DB::ArgumentExtractor::ParsedArguments const&) const @ 0x000000001f523166 8. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:110: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f522260 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b6ae 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 2025.06.13 08:59:10.412313 [ 15867 ] {} TCPHandler: Code: 36. DB::Exception: Invalid arguments, key_value_delimiter conflicts with pair delimiters: In scope WITH extractKeyValuePairs('not_important', ':', ',:', '\'') AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Functions/keyvaluepair/impl/Configuration.cpp:69: DB::extractKV::ConfigurationFactory::validate(char, char, std::vector>) @ 0x000000001f537056 5. ./build_docker/./src/Functions/keyvaluepair/impl/Configuration.cpp:23: DB::extractKV::ConfigurationFactory::createWithoutEscaping(char, char, std::vector>) @ 0x000000001f5366e9 6. ./src/Functions/keyvaluepair/impl/KeyValuePairExtractorBuilder.h:27: DB::KeyValuePairExtractorBuilder::buildWithoutEscaping() const @ 0x000000001f5244a6 7. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:59: DB::ExtractKeyValuePairs::getExtractor(DB::ArgumentExtractor::ParsedArguments const&) const @ 0x000000001f523166 8. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:110: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f522260 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b6ae 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 2025.06.13 08:59:10.830746 [ 15867 ] {32d73c09-43c8-4b13-a52d-5213ac28d228} executeQuery: Code: 36. DB::Exception: Control character argument must either be empty or contain exactly 1 character: In scope WITH extractKeyValuePairs('not_important', ':', ',', '\':') AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36960) (comment: 02499_extract_key_value_pairs_multiple_input.sql) (query 24, line 309) (in query: -- should fail because key value delimiter conflicts with quoting characters WITH extractKeyValuePairs('not_important', ':', ',', '\':') AS s_map, CAST( arrayMap( (x) -> (x, s_map[x]), arraySort(mapKeys(s_map)) ), 'Map(String,String)' ) AS x SELECT x;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:94: DB::ArgumentExtractor::extractSingleCharacter(DB::ColumnWithTypeAndName const&, String const&) @ 0x000000001f51ce8b 5. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:66: DB::ArgumentExtractor::extract(std::list>) @ 0x000000001f51b4ae 6. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:29: DB::ArgumentExtractor::extract(std::vector> const&) @ 0x000000001f51ab6a 7. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:108: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f5221af 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b6ae 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b6ae 2025.06.13 08:59:10.845056 [ 15867 ] {} TCPHandler: Code: 36. DB::Exception: Control character argument must either be empty or contain exactly 1 character: In scope WITH extractKeyValuePairs('not_important', ':', ',', '\':') AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:94: DB::ArgumentExtractor::extractSingleCharacter(DB::ColumnWithTypeAndName const&, String const&) @ 0x000000001f51ce8b 5. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:66: DB::ArgumentExtractor::extract(std::list>) @ 0x000000001f51b4ae 6. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:29: DB::ArgumentExtractor::extract(std::vector> const&) @ 0x000000001f51ab6a 7. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:108: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f5221af 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b6ae 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b6ae 2025.06.13 08:59:11.231558 [ 15867 ] {06cb26ee-9f64-43c6-9703-8eaf5ce79b6b} executeQuery: Code: 36. DB::Exception: Invalid arguments, quoting_character conflicts with pair delimiters: In scope WITH extractKeyValuePairs('not_important', ':', ',', ',') AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36960) (comment: 02499_extract_key_value_pairs_multiple_input.sql) (query 25, line 321) (in query: -- should fail because pair delimiters conflicts with quoting characters WITH extractKeyValuePairs('not_important', ':', ',', ',') AS s_map, CAST( arrayMap( (x) -> (x, s_map[x]), arraySort(mapKeys(s_map)) ), 'Map(String,String)' ) AS x SELECT x;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Functions/keyvaluepair/impl/Configuration.cpp:77: DB::extractKV::ConfigurationFactory::validate(char, char, std::vector>) @ 0x000000001f537172 5. ./build_docker/./src/Functions/keyvaluepair/impl/Configuration.cpp:23: DB::extractKV::ConfigurationFactory::createWithoutEscaping(char, char, std::vector>) @ 0x000000001f5366e9 6. ./src/Functions/keyvaluepair/impl/KeyValuePairExtractorBuilder.h:27: DB::KeyValuePairExtractorBuilder::buildWithoutEscaping() const @ 0x000000001f5244a6 7. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:59: DB::ExtractKeyValuePairs::getExtractor(DB::ArgumentExtractor::ParsedArguments const&) const @ 0x000000001f523166 8. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:110: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f522260 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b6ae 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 2025.06.13 08:59:11.243367 [ 15867 ] {} TCPHandler: Code: 36. DB::Exception: Invalid arguments, quoting_character conflicts with pair delimiters: In scope WITH extractKeyValuePairs('not_important', ':', ',', ',') AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Functions/keyvaluepair/impl/Configuration.cpp:77: DB::extractKV::ConfigurationFactory::validate(char, char, std::vector>) @ 0x000000001f537172 5. ./build_docker/./src/Functions/keyvaluepair/impl/Configuration.cpp:23: DB::extractKV::ConfigurationFactory::createWithoutEscaping(char, char, std::vector>) @ 0x000000001f5366e9 6. ./src/Functions/keyvaluepair/impl/KeyValuePairExtractorBuilder.h:27: DB::KeyValuePairExtractorBuilder::buildWithoutEscaping() const @ 0x000000001f5244a6 7. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:59: DB::ExtractKeyValuePairs::getExtractor(DB::ArgumentExtractor::ParsedArguments const&) const @ 0x000000001f523166 8. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:110: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f522260 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b6ae 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 2025.06.13 08:59:11.560176 [ 15867 ] {ec6b5bc9-0a50-408e-9a22-f4b17ac5d87f} executeQuery: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument data_column. Must be String.: In scope WITH extractKeyValuePairs([1, 2]) AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36960) (comment: 02499_extract_key_value_pairs_multiple_input.sql) (query 26, line 333) (in query: -- should fail because data_column argument must be of type String WITH extractKeyValuePairs([1, 2]) AS s_map, CAST( arrayMap( (x) -> (x, s_map[x]), arraySort(mapKeys(s_map)) ), 'Map(String,String)' ) AS x SELECT x;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception&, String const&>(int, FormatStringHelperImpl&>::type, std::type_identity::type>, std::shared_ptr&, String const&) @ 0x000000001f51e14d 4. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:123: DB::ArgumentExtractor::validateColumnType(std::shared_ptr, String const&) @ 0x000000001f51da25 5. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:102: DB::ArgumentExtractor::extractStringColumn(DB::ColumnWithTypeAndName const&, String const&) @ 0x000000001f51c0b6 6. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:43: DB::ArgumentExtractor::extract(std::list>) @ 0x000000001f51afca 7. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:29: DB::ArgumentExtractor::extract(std::vector> const&) @ 0x000000001f51ab6a 8. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:108: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f5221af 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b6ae 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 2025.06.13 08:59:11.574109 [ 15867 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument data_column. Must be String.: In scope WITH extractKeyValuePairs([1, 2]) AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception&, String const&>(int, FormatStringHelperImpl&>::type, std::type_identity::type>, std::shared_ptr&, String const&) @ 0x000000001f51e14d 4. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:123: DB::ArgumentExtractor::validateColumnType(std::shared_ptr, String const&) @ 0x000000001f51da25 5. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:102: DB::ArgumentExtractor::extractStringColumn(DB::ColumnWithTypeAndName const&, String const&) @ 0x000000001f51c0b6 6. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:43: DB::ArgumentExtractor::extract(std::list>) @ 0x000000001f51afca 7. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:29: DB::ArgumentExtractor::extract(std::vector> const&) @ 0x000000001f51ab6a 8. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:108: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f5221af 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b6ae 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 2025.06.13 08:59:11.925817 [ 15867 ] {5937d395-05f7-432e-91c1-37d5df53c2cc} executeQuery: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument key_value_delimiter. Must be String.: In scope WITH extractKeyValuePairs('', [1, 2]) AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36960) (comment: 02499_extract_key_value_pairs_multiple_input.sql) (query 27, line 345) (in query: -- should fail because key_value_delimiter argument must be of type String WITH extractKeyValuePairs('', [1, 2]) AS s_map, CAST( arrayMap( (x) -> (x, s_map[x]), arraySort(mapKeys(s_map)) ), 'Map(String,String)' ) AS x SELECT x;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception&, String const&>(int, FormatStringHelperImpl&>::type, std::type_identity::type>, std::shared_ptr&, String const&) @ 0x000000001f51e14d 4. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:123: DB::ArgumentExtractor::validateColumnType(std::shared_ptr, String const&) @ 0x000000001f51da25 5. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:81: DB::ArgumentExtractor::extractSingleCharacter(DB::ColumnWithTypeAndName const&, String const&) @ 0x000000001f51ca86 6. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:50: DB::ArgumentExtractor::extract(std::list>) @ 0x000000001f51b13a 7. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:29: DB::ArgumentExtractor::extract(std::vector> const&) @ 0x000000001f51ab6a 8. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:108: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f5221af 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b6ae 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 2025.06.13 08:59:11.932079 [ 15867 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument key_value_delimiter. Must be String.: In scope WITH extractKeyValuePairs('', [1, 2]) AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception&, String const&>(int, FormatStringHelperImpl&>::type, std::type_identity::type>, std::shared_ptr&, String const&) @ 0x000000001f51e14d 4. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:123: DB::ArgumentExtractor::validateColumnType(std::shared_ptr, String const&) @ 0x000000001f51da25 5. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:81: DB::ArgumentExtractor::extractSingleCharacter(DB::ColumnWithTypeAndName const&, String const&) @ 0x000000001f51ca86 6. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:50: DB::ArgumentExtractor::extract(std::list>) @ 0x000000001f51b13a 7. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:29: DB::ArgumentExtractor::extract(std::vector> const&) @ 0x000000001f51ab6a 8. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:108: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f5221af 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b6ae 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 2025.06.13 08:59:12.257177 [ 15867 ] {75417814-3f76-4e80-8ce9-952f0d135fc3} executeQuery: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument pair_delimiters. Must be String.: In scope WITH extractKeyValuePairs('', ':', [1, 2]) AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36960) (comment: 02499_extract_key_value_pairs_multiple_input.sql) (query 28, line 357) (in query: -- should fail because pair_delimiters argument must be of type String WITH extractKeyValuePairs('', ':', [1, 2]) AS s_map, CAST( arrayMap( (x) -> (x, s_map[x]), arraySort(mapKeys(s_map)) ), 'Map(String,String)' ) AS x SELECT x;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception&, String const&>(int, FormatStringHelperImpl&>::type, std::type_identity::type>, std::shared_ptr&, String const&) @ 0x000000001f51e14d 4. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:123: DB::ArgumentExtractor::validateColumnType(std::shared_ptr, String const&) @ 0x000000001f51da25 5. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:112: DB::ArgumentExtractor::extractVector(DB::ColumnWithTypeAndName const&, String const&) @ 0x000000001f51d1e9 6. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:57: DB::ArgumentExtractor::extract(std::list>) @ 0x000000001f51b31d 7. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:29: DB::ArgumentExtractor::extract(std::vector> const&) @ 0x000000001f51ab6a 8. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:108: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f5221af 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b6ae 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 2025.06.13 08:59:12.262967 [ 15867 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument pair_delimiters. Must be String.: In scope WITH extractKeyValuePairs('', ':', [1, 2]) AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception&, String const&>(int, FormatStringHelperImpl&>::type, std::type_identity::type>, std::shared_ptr&, String const&) @ 0x000000001f51e14d 4. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:123: DB::ArgumentExtractor::validateColumnType(std::shared_ptr, String const&) @ 0x000000001f51da25 5. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:112: DB::ArgumentExtractor::extractVector(DB::ColumnWithTypeAndName const&, String const&) @ 0x000000001f51d1e9 6. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:57: DB::ArgumentExtractor::extract(std::list>) @ 0x000000001f51b31d 7. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:29: DB::ArgumentExtractor::extract(std::vector> const&) @ 0x000000001f51ab6a 8. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:108: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f5221af 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b6ae 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 2025.06.13 08:59:12.617166 [ 15867 ] {b0504ef1-df94-4e7e-bfb0-69899b560586} executeQuery: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument quoting_character. Must be String.: In scope WITH extractKeyValuePairs('', ':', ' ', [1, 2]) AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36960) (comment: 02499_extract_key_value_pairs_multiple_input.sql) (query 29, line 369) (in query: -- should fail because quoting_character argument must be of type String WITH extractKeyValuePairs('', ':', ' ', [1, 2]) AS s_map, CAST( arrayMap( (x) -> (x, s_map[x]), arraySort(mapKeys(s_map)) ), 'Map(String,String)' ) AS x SELECT x;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception&, String const&>(int, FormatStringHelperImpl&>::type, std::type_identity::type>, std::shared_ptr&, String const&) @ 0x000000001f51e14d 4. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:123: DB::ArgumentExtractor::validateColumnType(std::shared_ptr, String const&) @ 0x000000001f51da25 5. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:81: DB::ArgumentExtractor::extractSingleCharacter(DB::ColumnWithTypeAndName const&, String const&) @ 0x000000001f51ca86 6. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:66: DB::ArgumentExtractor::extract(std::list>) @ 0x000000001f51b4ae 7. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:29: DB::ArgumentExtractor::extract(std::vector> const&) @ 0x000000001f51ab6a 8. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:108: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f5221af 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b6ae 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 2025.06.13 08:59:12.624175 [ 15867 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument quoting_character. Must be String.: In scope WITH extractKeyValuePairs('', ':', ' ', [1, 2]) AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception&, String const&>(int, FormatStringHelperImpl&>::type, std::type_identity::type>, std::shared_ptr&, String const&) @ 0x000000001f51e14d 4. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:123: DB::ArgumentExtractor::validateColumnType(std::shared_ptr, String const&) @ 0x000000001f51da25 5. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:81: DB::ArgumentExtractor::extractSingleCharacter(DB::ColumnWithTypeAndName const&, String const&) @ 0x000000001f51ca86 6. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:66: DB::ArgumentExtractor::extract(std::list>) @ 0x000000001f51b4ae 7. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:29: DB::ArgumentExtractor::extract(std::vector> const&) @ 0x000000001f51ab6a 8. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:108: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f5221af 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b6ae 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 2025.06.13 08:59:12.976250 [ 15867 ] {0c1b6374-ed8f-464f-ab65-54c746333e26} executeQuery: Code: 36. DB::Exception: Invalid arguments, pair delimiters can contain at most 8 characters: In scope WITH extractKeyValuePairs('not_important', ':', '123456789', '\'') AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36960) (comment: 02499_extract_key_value_pairs_multiple_input.sql) (query 30, line 381) (in query: -- should fail because pair delimiters can contain at most 8 characters WITH extractKeyValuePairs('not_important', ':', '123456789', '\'') AS s_map, CAST( arrayMap( (x) -> (x, s_map[x]), arraySort(mapKeys(s_map)) ), 'Map(String,String)' ) AS x SELECT x;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned int const&) @ 0x000000001f53786a 4. ./build_docker/./src/Functions/keyvaluepair/impl/Configuration.cpp:56: DB::extractKV::ConfigurationFactory::validate(char, char, std::vector>) @ 0x000000001f536dd9 5. ./build_docker/./src/Functions/keyvaluepair/impl/Configuration.cpp:23: DB::extractKV::ConfigurationFactory::createWithoutEscaping(char, char, std::vector>) @ 0x000000001f5366e9 6. ./src/Functions/keyvaluepair/impl/KeyValuePairExtractorBuilder.h:27: DB::KeyValuePairExtractorBuilder::buildWithoutEscaping() const @ 0x000000001f5244a6 7. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:59: DB::ExtractKeyValuePairs::getExtractor(DB::ArgumentExtractor::ParsedArguments const&) const @ 0x000000001f523166 8. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:110: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f522260 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b6ae 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 2025.06.13 08:59:12.986585 [ 15867 ] {} TCPHandler: Code: 36. DB::Exception: Invalid arguments, pair delimiters can contain at most 8 characters: In scope WITH extractKeyValuePairs('not_important', ':', '123456789', '\'') AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned int const&) @ 0x000000001f53786a 4. ./build_docker/./src/Functions/keyvaluepair/impl/Configuration.cpp:56: DB::extractKV::ConfigurationFactory::validate(char, char, std::vector>) @ 0x000000001f536dd9 5. ./build_docker/./src/Functions/keyvaluepair/impl/Configuration.cpp:23: DB::extractKV::ConfigurationFactory::createWithoutEscaping(char, char, std::vector>) @ 0x000000001f5366e9 6. ./src/Functions/keyvaluepair/impl/KeyValuePairExtractorBuilder.h:27: DB::KeyValuePairExtractorBuilder::buildWithoutEscaping() const @ 0x000000001f5244a6 7. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:59: DB::ExtractKeyValuePairs::getExtractor(DB::ArgumentExtractor::ParsedArguments const&) const @ 0x000000001f523166 8. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:110: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f522260 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b6ae 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 2025.06.13 08:59:13.334400 [ 15867 ] {c0261c83-d758-45cd-a274-0c7bcc2a3d93} executeQuery: Code: 42. DB::Exception: Function extractKeyValuePairs requires at least 1 argument and at most 4. 0 was provided: In scope WITH extractKeyValuePairs() AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36960) (comment: 02499_extract_key_value_pairs_multiple_input.sql) (query 31, line 393) (in query: -- should fail because no argument has been provided WITH extractKeyValuePairs() AS s_map, CAST( arrayMap( (x) -> (x, s_map[x]), arraySort(mapKeys(s_map)) ), 'Map(String,String)' ) AS x SELECT x;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int const&, unsigned long&&) @ 0x000000001f51dded 4. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:38: DB::ArgumentExtractor::extract(std::list>) @ 0x000000001f51ba41 5. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:29: DB::ArgumentExtractor::extract(std::vector> const&) @ 0x000000001f51ab6a 6. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:108: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f5221af 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b6ae 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b6ae 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 2025.06.13 08:59:13.341534 [ 15867 ] {} TCPHandler: Code: 42. DB::Exception: Function extractKeyValuePairs requires at least 1 argument and at most 4. 0 was provided: In scope WITH extractKeyValuePairs() AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int const&, unsigned long&&) @ 0x000000001f51dded 4. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:38: DB::ArgumentExtractor::extract(std::list>) @ 0x000000001f51ba41 5. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:29: DB::ArgumentExtractor::extract(std::vector> const&) @ 0x000000001f51ab6a 6. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:108: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f5221af 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b6ae 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b6ae 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 2025.06.13 08:59:13.420102 [ 15867 ] {0d19ba7d-14ae-4c0a-a5dc-4757698cf949} executeQuery: Code: 42. DB::Exception: Function extractKeyValuePairs requires at least 1 argument and at most 4. 5 was provided: In scope WITH extractKeyValuePairs('a', ':', ',', '"', '') AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36960) (comment: 02499_extract_key_value_pairs_multiple_input.sql) (query 32, line 405) (in query: -- should fail because one extra argument / non existent has been provided WITH extractKeyValuePairs('a', ':', ',', '"', '') AS s_map, CAST( arrayMap( (x) -> (x, s_map[x]), arraySort(mapKeys(s_map)) ), 'Map(String,String)' ) AS x SELECT x;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int const&, unsigned long&&) @ 0x000000001f51dded 4. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:38: DB::ArgumentExtractor::extract(std::list>) @ 0x000000001f51ba41 5. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:29: DB::ArgumentExtractor::extract(std::vector> const&) @ 0x000000001f51ab6a 6. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:108: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f5221af 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b6ae 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b6ae 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 2025.06.13 08:59:13.428444 [ 15867 ] {} TCPHandler: Code: 42. DB::Exception: Function extractKeyValuePairs requires at least 1 argument and at most 4. 5 was provided: In scope WITH extractKeyValuePairs('a', ':', ',', '"', '') AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int const&, unsigned long&&) @ 0x000000001f51dded 4. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:38: DB::ArgumentExtractor::extract(std::list>) @ 0x000000001f51ba41 5. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:29: DB::ArgumentExtractor::extract(std::vector> const&) @ 0x000000001f51ab6a 6. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:108: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f5221af 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b6ae 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b6ae 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 2025.06.13 08:59:13.847384 [ 15867 ] {03c22412-693a-45a9-a296-d19561e3362a} executeQuery: Code: 290. DB::Exception: Number of pairs produced exceeded the limit of 1: In scope WITH extractKeyValuePairs('key1:value1,key2:value2') AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36960) (comment: 02499_extract_key_value_pairs_multiple_input.sql) (query 34, line 419) (in query: WITH extractKeyValuePairs('key1:value1,key2:value2') AS s_map, CAST( arrayMap( (x) -> (x, s_map[x]), arraySort(mapKeys(s_map)) ), 'Map(String,String)' ) AS x SELECT x;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000d04bc6a 4. ./src/Functions/keyvaluepair/impl/CHKeyValuePairExtractor.h:119: DB::extractKV::StateHandler::NextState DB::extractKV::KeyValuePairExtractor::flushPair(std::basic_string_view> const&, DB::extractKV::NoEscapingStateHandler::PairWriter&, unsigned long&) @ 0x000000001f5296eb 5. ./src/Functions/keyvaluepair/impl/CHKeyValuePairExtractor.h:104: DB::extractKV::StateHandler::NextState DB::extractKV::KeyValuePairExtractor::processState(std::basic_string_view>, DB::extractKV::StateHandler::State, DB::extractKV::NoEscapingStateHandler::PairWriter&, unsigned long&) @ 0x000000001f528a13 6. ./src/Functions/keyvaluepair/impl/CHKeyValuePairExtractor.h:49: DB::extractKV::KeyValuePairExtractor::extractImpl(std::basic_string_view>, DB::extractKV::NoEscapingStateHandler::PairWriter&) @ 0x000000001f5278cf 7. ./src/Functions/keyvaluepair/impl/CHKeyValuePairExtractor.h:149: COW::immutable_ptr DB::ExtractKeyValuePairs::extract(COW::immutable_ptr, DB::KeyValuePairExtractorNoEscaping&, unsigned long) const @ 0x000000001f5238ca 8. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:112: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f5222d8 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b6ae 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 2025.06.13 08:59:13.854626 [ 15867 ] {} TCPHandler: Code: 290. DB::Exception: Number of pairs produced exceeded the limit of 1: In scope WITH extractKeyValuePairs('key1:value1,key2:value2') AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000d04bc6a 4. ./src/Functions/keyvaluepair/impl/CHKeyValuePairExtractor.h:119: DB::extractKV::StateHandler::NextState DB::extractKV::KeyValuePairExtractor::flushPair(std::basic_string_view> const&, DB::extractKV::NoEscapingStateHandler::PairWriter&, unsigned long&) @ 0x000000001f5296eb 5. ./src/Functions/keyvaluepair/impl/CHKeyValuePairExtractor.h:104: DB::extractKV::StateHandler::NextState DB::extractKV::KeyValuePairExtractor::processState(std::basic_string_view>, DB::extractKV::StateHandler::State, DB::extractKV::NoEscapingStateHandler::PairWriter&, unsigned long&) @ 0x000000001f528a13 6. ./src/Functions/keyvaluepair/impl/CHKeyValuePairExtractor.h:49: DB::extractKV::KeyValuePairExtractor::extractImpl(std::basic_string_view>, DB::extractKV::NoEscapingStateHandler::PairWriter&) @ 0x000000001f5278cf 7. ./src/Functions/keyvaluepair/impl/CHKeyValuePairExtractor.h:149: COW::immutable_ptr DB::ExtractKeyValuePairs::extract(COW::immutable_ptr, DB::KeyValuePairExtractorNoEscaping&, unsigned long) const @ 0x000000001f5238ca 8. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:112: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f5222d8 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b6ae 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 2025.06.13 08:59:14.724885 [ 15838 ] {fb2094c9-f8be-4a98-b237-dc406a9c1b9e} executeQuery: Code: 269. DB::Exception: Distributed table distr looks at itself. (INFINITE_LOOP) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39092) (comment: 00987_distributed_stack_overflow.sql) (query 4, line 7) (in query: CREATE TABLE distr (x UInt8) ENGINE = Distributed(test_shard_localhost, currentDatabase(), distr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/StorageDistributed.cpp:430: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr, bool) @ 0x0000000038351d00 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String&, String&, String&, std::shared_ptr const&, std::shared_ptr const&, String&, String const&, DB::DistributedSettings&, DB::LoadingStrictnessLevel const&, 0>(std::allocator const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String&, String&, String&, std::shared_ptr const&, std::shared_ptr const&, String&, String const&, DB::DistributedSettings&, DB::LoadingStrictnessLevel const&) @ 0x00000000383c81a1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000383aee70 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:59:14.731754 [ 15838 ] {} TCPHandler: Code: 269. DB::Exception: Distributed table distr looks at itself. (INFINITE_LOOP), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/StorageDistributed.cpp:430: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr, bool) @ 0x0000000038351d00 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String&, String&, String&, std::shared_ptr const&, std::shared_ptr const&, String&, String const&, DB::DistributedSettings&, DB::LoadingStrictnessLevel const&, 0>(std::allocator const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String&, String&, String&, std::shared_ptr const&, std::shared_ptr const&, String&, String const&, DB::DistributedSettings&, DB::LoadingStrictnessLevel const&) @ 0x00000000383c81a1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000383aee70 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:59:14.768225 [ 15838 ] {0bba9d29-ece7-4eee-bfc1-0de29debf3b3} StorageDistributed (distr0): Name of remote database is empty. Default database will be used implicitly. 2025.06.13 08:59:14.779364 [ 15838 ] {0bba9d29-ece7-4eee-bfc1-0de29debf3b3} executeQuery: Code: 269. DB::Exception: Distributed table distr0 looks at itself. (INFINITE_LOOP) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39092) (comment: 00987_distributed_stack_overflow.sql) (query 5, line 9) (in query: CREATE TABLE distr0 (x UInt8) ENGINE = Distributed(test_shard_localhost, '', distr0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/StorageDistributed.cpp:430: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr, bool) @ 0x0000000038351d00 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String&, String&, String&, std::shared_ptr const&, std::shared_ptr const&, String&, String const&, DB::DistributedSettings&, DB::LoadingStrictnessLevel const&, 0>(std::allocator const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String&, String&, String&, std::shared_ptr const&, std::shared_ptr const&, String&, String const&, DB::DistributedSettings&, DB::LoadingStrictnessLevel const&) @ 0x00000000383c81a1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000383aee70 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:59:14.788468 [ 15838 ] {} TCPHandler: Code: 269. DB::Exception: Distributed table distr0 looks at itself. (INFINITE_LOOP), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/StorageDistributed.cpp:430: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr, bool) @ 0x0000000038351d00 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String&, String&, String&, std::shared_ptr const&, std::shared_ptr const&, String&, String const&, DB::DistributedSettings&, DB::LoadingStrictnessLevel const&, 0>(std::allocator const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String&, String&, String&, std::shared_ptr const&, std::shared_ptr const&, String&, String const&, DB::DistributedSettings&, DB::LoadingStrictnessLevel const&) @ 0x00000000383c81a1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000383aee70 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 08:59:15.085651 [ 15838 ] {4fdf1fed-b940-4ecc-ba36-fe08ca072677} executeQuery: Code: 269. DB::Exception: Cannot add dependencies for 'test_qb6xor0o.distr2', because it will lead to cyclic dependencies: test_qb6xor0o.distr1 -> [test_qb6xor0o.distr2]; test_qb6xor0o.distr2 -> [test_qb6xor0o.distr1]. (INFINITE_LOOP) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39092) (comment: 00987_distributed_stack_overflow.sql) (query 7, line 12) (in query: CREATE TABLE distr2 (x UInt8) ENGINE = Distributed(test_shard_localhost, currentDatabase(), distr1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000d28002d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1594: DB::DatabaseCatalog::checkTableCanBeAddedWithNoCyclicDependencies(DB::QualifiedTableName const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&)::$_0::operator()(DB::TablesDependencyGraph&, std::unordered_set, std::equal_to, std::allocator> const&) const @ 0x0000000031a2e241 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1604: DB::DatabaseCatalog::checkTableCanBeAddedWithNoCyclicDependencies(DB::QualifiedTableName const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&) @ 0x0000000031a2d8d6 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1493: DB::(anonymous namespace)::checkTableCanBeAddedWithNoCyclicDependencies(DB::ASTCreateQuery const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032926d5d 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1911: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291a252 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:59:15.092256 [ 15838 ] {} TCPHandler: Code: 269. DB::Exception: Cannot add dependencies for 'test_qb6xor0o.distr2', because it will lead to cyclic dependencies: test_qb6xor0o.distr1 -> [test_qb6xor0o.distr2]; test_qb6xor0o.distr2 -> [test_qb6xor0o.distr1]. (INFINITE_LOOP), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000d28002d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1594: DB::DatabaseCatalog::checkTableCanBeAddedWithNoCyclicDependencies(DB::QualifiedTableName const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&)::$_0::operator()(DB::TablesDependencyGraph&, std::unordered_set, std::equal_to, std::allocator> const&) const @ 0x0000000031a2e241 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1604: DB::DatabaseCatalog::checkTableCanBeAddedWithNoCyclicDependencies(DB::QualifiedTableName const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&) @ 0x0000000031a2d8d6 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1493: DB::(anonymous namespace)::checkTableCanBeAddedWithNoCyclicDependencies(DB::ASTCreateQuery const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032926d5d 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1911: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291a252 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:59:20.405981 [ 24861 ] {739a56d4-3c74-449d-99ad-929f042a7e3c} executeQuery: Code: 46. DB::Exception: Function with name `viewExplain` does not exist. In scope viewExplain('EXPLAIN PIPELINE', 'graph = 1', (SELECT * FROM remote('127.0.0.4', system, one))). (UNKNOWN_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39136) (comment: 03213_distributed_analyzer.sql) (query 1, line 1) (in query: -- This triggered a nullptr dereference due to the confusion between old and new analyzers: SELECT sum(*) FROM remote('127.0.0.4', currentDatabase(), viewExplain('EXPLAIN PIPELINE', 'graph = 1', (SELECT * FROM remote('127.0.0.4', system, one))));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3350: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003038f5f5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:254: DB::QueryAnalyzer::resolveConstantExpression(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003033a785 7. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:115: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x00000000336b2d0b 8. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:196: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000336b81b3 9. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:207: DB::evaluateConstantExpressionAsLiteral(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000336b87a5 10. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:215: DB::evaluateConstantExpressionOrIdentifierAsLiteral(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000336b8b03 11. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:188: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002659210f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:59:20.470306 [ 24861 ] {} TCPHandler: Code: 46. DB::Exception: Function with name `viewExplain` does not exist. In scope viewExplain('EXPLAIN PIPELINE', 'graph = 1', (SELECT * FROM remote('127.0.0.4', system, one))). (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3350: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003038f5f5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:254: DB::QueryAnalyzer::resolveConstantExpression(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000003033a785 7. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:115: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x00000000336b2d0b 8. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:196: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000336b81b3 9. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:207: DB::evaluateConstantExpressionAsLiteral(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000336b87a5 10. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:215: DB::evaluateConstantExpressionOrIdentifierAsLiteral(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000336b8b03 11. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:188: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002659210f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 08:59:25.365381 [ 9261 ] {099ab515-08cc-4f32-ae89-49528761ee79} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_aliases' in scope alias2 AS (SELECT number FROM test_aliases). (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38938) (comment: 02834_analyzer_with_statement_references.sql) (query 3, line 6) (in query: WITH test_aliases AS (SELECT number FROM numbers(20)), alias2 AS (SELECT number FROM test_aliases) SELECT number FROM alias2 SETTINGS enable_global_with_statement = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032612b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8db2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:59:25.372519 [ 9261 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_aliases' in scope alias2 AS (SELECT number FROM test_aliases). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032612b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8db2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 08:59:29.371371 [ 15875 ] {c118157b-f866-4fa9-8bc2-467e39c6d457} executeQuery: Code: 47. DB::Exception: Missing columns: 'All' while processing: '`All`', required columns: 'All', available columns: 'id'. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39084) (comment: 03316_fixup_used_columns_exception.sh) (query 1, line 2) (in query: CREATE TABLE test_exception (`id` UInt64) ENGINE = MergeTree ORDER BY `All` SETTINGS index_granularity = 38302, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 30, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 205982289, compact_parts_max_granules_to_buffer = 236, compact_parts_merge_max_bytes_to_prefetch_part = 12550623, merge_max_block_size = 1042, old_parts_lifetime = 270., prefer_fetch_merged_part_size_threshold = 3917889528, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10537967312, index_granularity_bytes = 16844994, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 22722, primary_key_compress_block_size = 31027, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1303: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x0000000033504085 4. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1561: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003352681b 5. ./build_docker/./src/Storages/KeyDescription.cpp:163: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000038292ce9 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a379e36 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:59:29.391129 [ 15875 ] {} TCPHandler: Code: 47. DB::Exception: Missing columns: 'All' while processing: '`All`', required columns: 'All', available columns: 'id'. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1303: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x0000000033504085 4. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1561: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003352681b 5. ./build_docker/./src/Storages/KeyDescription.cpp:163: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000038292ce9 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a379e36 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:59:33.891784 [ 24860 ] {975d7e11-6d99-43cd-8599-0cf48d1f0695} executeQuery: Code: 125. DB::Exception: Scalar subquery returned empty result of type Tuple(Array(Nullable(Float64)), String) which cannot be Nullable. (INCORRECT_RESULT_OF_SCALAR_SUBQUERY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38974) (comment: 01651_bugs_from_15889.sql) (query 16, line 45) (in query: WITH concat(addressToLine(arrayJoin(trace) AS addr), '#') AS symbol SELECT count() > 7 FROM trace_log AS t WHERE (query_id = ( SELECT [NULL, NULL, NULL, NULL, 0.00009999999747378752, NULL, NULL, NULL, NULL, NULL], query_id FROM system.query_log WHERE current_database = currentDatabase() AND (query LIKE '%test cpu time query profiler%') AND (query NOT LIKE '%system%') ORDER BY event_time DESC LIMIT 1 )) AND (symbol LIKE '%Source%');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:645: DB::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030345e79 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3874: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030329cfb 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030d28a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 08:59:33.917079 [ 24860 ] {} TCPHandler: Code: 125. DB::Exception: Scalar subquery returned empty result of type Tuple(Array(Nullable(Float64)), String) which cannot be Nullable. (INCORRECT_RESULT_OF_SCALAR_SUBQUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:645: DB::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030345e79 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3874: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030329cfb 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030d28a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 08:59:34.435345 [ 24860 ] {912f9127-675a-4e78-aec6-c5d60af521d9} executeQuery: Code: 42. DB::Exception: Number of arguments for function greaterOrEquals doesn't match: passed 3, should be 2: In scope WITH addressToSymbol(arrayJoin(trace)) AS symbol SELECT count() > 0 FROM trace_log AS t WHERE greaterOrEquals(event_date, ignore(ignore(ignore(NULL, '')), 256), yesterday()) AND (trace_type = 'Memory') AND (query_id = (SELECT ignore(ignore(ignore(ignore(65536)), ignore(65537), ignore(2)), ''), query_id FROM system.query_log WHERE (current_database = currentDatabase()) AND (event_date >= yesterday()) AND (query LIKE '%test memory profiler%') ORDER BY event_time DESC LIMIT 1)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38974) (comment: 01651_bugs_from_15889.sql) (query 17, line 60) (in query: WITH addressToSymbol(arrayJoin(trace)) AS symbol SELECT count() > 0 FROM trace_log AS t WHERE greaterOrEquals(event_date, ignore(ignore(ignore(NULL, '')), 256), yesterday()) AND (trace_type = 'Memory') AND (query_id = ( SELECT ignore(ignore(ignore(ignore(65536)), ignore(65537), ignore(2)), ''), query_id FROM system.query_log WHERE current_database = currentDatabase() AND (event_date >= yesterday()) AND (query LIKE '%test memory profiler%') ORDER BY event_time DESC LIMIT 1 ));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030d28a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 29. ? @ 0x00007f5206343ac3 30. ? @ 0x00007f52063d5850 2025.06.13 08:59:34.451991 [ 24860 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greaterOrEquals doesn't match: passed 3, should be 2: In scope WITH addressToSymbol(arrayJoin(trace)) AS symbol SELECT count() > 0 FROM trace_log AS t WHERE greaterOrEquals(event_date, ignore(ignore(ignore(NULL, '')), 256), yesterday()) AND (trace_type = 'Memory') AND (query_id = (SELECT ignore(ignore(ignore(ignore(65536)), ignore(65537), ignore(2)), ''), query_id FROM system.query_log WHERE (current_database = currentDatabase()) AND (event_date >= yesterday()) AND (query LIKE '%test memory profiler%') ORDER BY event_time DESC LIMIT 1)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030d28a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 29. ? @ 0x00007f5206343ac3 30. ? @ 0x00007f52063d5850 2025.06.13 08:59:37.613807 [ 2085 ] {b39d450b-5297-4b12-bcde-cea85e60db89} executeQuery: Code: 630. DB::Exception: Cannot drop or rename test_ef8wco6l.src (4bd86b3f-bf14-4cc0-a767-6469f8caba22), because some tables depend on it: test_ef8wco6l.mv. (HAVE_DEPENDENT_OBJECTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:32978) (comment: 02552_check_referential_table_dependencies.sql) (query 8, line 11) (in query: -- Can't drop because of referential dependencies DROP TABLE src;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x0000000031a48ead 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1553: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x0000000031a2c0df 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1535: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x0000000031a2d676 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:300: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003296e232 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032968e1f 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965c79 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:59:37.624060 [ 2085 ] {} TCPHandler: Code: 630. DB::Exception: Cannot drop or rename test_ef8wco6l.src (4bd86b3f-bf14-4cc0-a767-6469f8caba22), because some tables depend on it: test_ef8wco6l.mv. (HAVE_DEPENDENT_OBJECTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x0000000031a48ead 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1553: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x0000000031a2c0df 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1535: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x0000000031a2d676 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:300: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003296e232 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032968e1f 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965c79 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:59:37.653003 [ 2085 ] {7c0c01cf-aea7-4a45-b7ee-eb328206ad5e} executeQuery: Code: 630. DB::Exception: Cannot drop or rename test_ef8wco6l.dst (b1a58aa9-fce2-413e-926d-5ff36b115f2e), because some tables depend on it: test_ef8wco6l.mv. (HAVE_DEPENDENT_OBJECTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:32978) (comment: 02552_check_referential_table_dependencies.sql) (query 9, line 13) (in query: DROP TABLE dst;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x0000000031a48ead 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1553: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x0000000031a2c0df 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1535: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x0000000031a2d676 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:300: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003296e232 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032968e1f 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965c79 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:59:37.662445 [ 2085 ] {} TCPHandler: Code: 630. DB::Exception: Cannot drop or rename test_ef8wco6l.dst (b1a58aa9-fce2-413e-926d-5ff36b115f2e), because some tables depend on it: test_ef8wco6l.mv. (HAVE_DEPENDENT_OBJECTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x0000000031a48ead 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1553: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x0000000031a2c0df 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1535: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x0000000031a2d676 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:300: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003296e232 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032968e1f 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965c79 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:59:38.985179 [ 24860 ] {6a3104d1-681d-43dc-b08d-05bc773a2a12} executeQuery: Code: 43. DB::Exception: Illegal type Tuple(inf Float64, query_start_time DateTime) of argument of function toDateTime: In scope WITH (SELECT query_start_time_microseconds FROM system.query_log WHERE current_database = currentDatabase() ORDER BY query_start_time DESC LIMIT 1) AS time_with_microseconds, (SELECT inf, query_start_time FROM system.query_log WHERE current_database = currentDatabase() ORDER BY query_start_time DESC LIMIT 1) AS t SELECT if(dateDiff('second', toDateTime(time_with_microseconds), toDateTime(t)) = -9223372036854775808, 'ok', ''). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38974) (comment: 01651_bugs_from_15889.sql) (query 20, line 78) (in query: WITH ( SELECT query_start_time_microseconds FROM system.query_log WHERE current_database = currentDatabase() ORDER BY query_start_time DESC LIMIT 1 ) AS time_with_microseconds, ( SELECT inf, query_start_time FROM system.query_log WHERE current_database = currentDatabase() ORDER BY query_start_time DESC LIMIT 1 ) AS t SELECT if(dateDiff('second', toDateTime(time_with_microseconds), toDateTime(t)) = -9223372036854775808, 'ok', '');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./src/Functions/FunctionsConversion.h:2543: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c837149 5. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c835be2 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030374611 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 2025.06.13 08:59:38.999444 [ 24860 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Tuple(inf Float64, query_start_time DateTime) of argument of function toDateTime: In scope WITH (SELECT query_start_time_microseconds FROM system.query_log WHERE current_database = currentDatabase() ORDER BY query_start_time DESC LIMIT 1) AS time_with_microseconds, (SELECT inf, query_start_time FROM system.query_log WHERE current_database = currentDatabase() ORDER BY query_start_time DESC LIMIT 1) AS t SELECT if(dateDiff('second', toDateTime(time_with_microseconds), toDateTime(t)) = -9223372036854775808, 'ok', ''). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./src/Functions/FunctionsConversion.h:2543: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c837149 5. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c835be2 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030374611 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 2025.06.13 08:59:39.598122 [ 24860 ] {a48a31ee-2f20-4096-ae14-e5a9bb96459a} executeQuery: Code: 43. DB::Exception: Illegal type Tuple(inf Float64, query_start_time DateTime) of argument of function toDateTime: In scope WITH ((SELECT query_start_time_microseconds FROM system.query_log WHERE current_database = currentDatabase() ORDER BY query_start_time DESC LIMIT 1) AS time_with_microseconds, (SELECT inf, query_start_time FROM system.query_log WHERE current_database = currentDatabase() ORDER BY query_start_time DESC LIMIT 1) AS t) SELECT if(dateDiff('second', toDateTime(time_with_microseconds), toDateTime(t)) = -9223372036854775808, 'ok', '') SETTINGS allow_experimental_analyzer = 1. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38974) (comment: 01651_bugs_from_15889.sql) (query 21, line 97) (in query: WITH ( ( SELECT query_start_time_microseconds FROM system.query_log WHERE current_database = currentDatabase() ORDER BY query_start_time DESC LIMIT 1 ) AS time_with_microseconds, ( SELECT inf, query_start_time FROM system.query_log WHERE current_database = currentDatabase() ORDER BY query_start_time DESC LIMIT 1 ) AS t) SELECT if(dateDiff('second', toDateTime(time_with_microseconds), toDateTime(t)) = -9223372036854775808, 'ok', '') SETTINGS allow_experimental_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./src/Functions/FunctionsConversion.h:2543: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c837149 5. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c835be2 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030374611 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 2025.06.13 08:59:39.613252 [ 24860 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Tuple(inf Float64, query_start_time DateTime) of argument of function toDateTime: In scope WITH ((SELECT query_start_time_microseconds FROM system.query_log WHERE current_database = currentDatabase() ORDER BY query_start_time DESC LIMIT 1) AS time_with_microseconds, (SELECT inf, query_start_time FROM system.query_log WHERE current_database = currentDatabase() ORDER BY query_start_time DESC LIMIT 1) AS t) SELECT if(dateDiff('second', toDateTime(time_with_microseconds), toDateTime(t)) = -9223372036854775808, 'ok', '') SETTINGS allow_experimental_analyzer = 1. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./src/Functions/FunctionsConversion.h:2543: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c837149 5. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c835be2 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2876: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030374611 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 2025.06.13 08:59:43.034981 [ 9260 ] {13f57671-05db-449b-b420-4ef9afd70e27} executeQuery: Code: 36. DB::Exception: ALTER MODIFY ORDER BY is not supported for default-partitioned tables created with the old syntax. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33142) (comment: 00754_alter_modify_order_by_replicated_zookeeper_long.sql) (query 6, line 12) (in query: ALTER TABLE old_style ADD COLUMN y UInt32, MODIFY ORDER BY (x, y);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3698: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003982285d 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 08:59:43.041863 [ 9260 ] {} TCPHandler: Code: 36. DB::Exception: ALTER MODIFY ORDER BY is not supported for default-partitioned tables created with the old syntax. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3698: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003982285d 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 08:59:44.359639 [ 9260 ] {0f12f645-a569-44cc-aeed-198bf542a9c9} executeQuery: Code: 36. DB::Exception: Existing column val is used in the expression that was added to the sorting key. You can add expressions that use only the newly added columns. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33142) (comment: 00754_alter_modify_order_by_replicated_zookeeper_long.sql) (query 12, line 20) (in query: /* Can't add an expression with existing column to ORDER BY. */ ALTER TABLE summing_r1 MODIFY ORDER BY (x, y, -val);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:781: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000039778b7a 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3860: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003981e60c 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 08:59:44.366699 [ 9260 ] {} TCPHandler: Code: 36. DB::Exception: Existing column val is used in the expression that was added to the sorting key. You can add expressions that use only the newly added columns. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:781: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000039778b7a 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3860: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003981e60c 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 08:59:44.642509 [ 9260 ] {bfadbeec-c2ff-47bd-a8ff-97ceeede39f2} executeQuery: Code: 36. DB::Exception: Newly added column z has a default expression, so adding expressions that use it to the sorting key is forbidden. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33142) (comment: 00754_alter_modify_order_by_replicated_zookeeper_long.sql) (query 13, line 23) (in query: /* Can't add an expression with existing column to ORDER BY. */ ALTER TABLE summing_r1 ADD COLUMN z UInt32 DEFAULT x + 1, MODIFY ORDER BY (x, y, -z);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:787: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000039779296 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3860: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003981e60c 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 08:59:44.650930 [ 9260 ] {} TCPHandler: Code: 36. DB::Exception: Newly added column z has a default expression, so adding expressions that use it to the sorting key is forbidden. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:787: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000039779296 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3860: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003981e60c 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 08:59:44.907149 [ 9260 ] {909bc5fb-5bdd-463f-9daf-a90cd85d201c} executeQuery: Code: 47. DB::Exception: Missing columns: 'nonexistent' while processing: 'x, y, nonexistent', required columns: 'x' 'y' 'nonexistent', available columns: 'val' 'y' 'x'. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33142) (comment: 00754_alter_modify_order_by_replicated_zookeeper_long.sql) (query 14, line 26) (in query: /* Can't add nonexistent column to ORDER BY. */ ALTER TABLE summing_r1 MODIFY ORDER BY (x, y, nonexistent);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1303: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x0000000033504085 4. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1561: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003352681b 5. ./build_docker/./src/Storages/KeyDescription.cpp:163: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000038292ce9 6. ./build_docker/./src/Storages/KeyDescription.cpp:78: DB::KeyDescription::recalculateWithNewAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x00000000382902c7 7. ./build_docker/./src/Storages/AlterCommands.cpp:666: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000038174aef 8. ./build_docker/./src/Storages/AlterCommands.cpp:1263: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000003818ab70 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003981884d 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:59:44.915000 [ 9260 ] {} TCPHandler: Code: 47. DB::Exception: Missing columns: 'nonexistent' while processing: 'x, y, nonexistent', required columns: 'x' 'y' 'nonexistent', available columns: 'val' 'y' 'x'. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1303: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x0000000033504085 4. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1561: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003352681b 5. ./build_docker/./src/Storages/KeyDescription.cpp:163: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000038292ce9 6. ./build_docker/./src/Storages/KeyDescription.cpp:78: DB::KeyDescription::recalculateWithNewAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x00000000382902c7 7. ./build_docker/./src/Storages/AlterCommands.cpp:666: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000038174aef 8. ./build_docker/./src/Storages/AlterCommands.cpp:1263: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000003818ab70 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003981884d 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 08:59:45.211274 [ 9260 ] {b5003c2f-9d66-4e48-bc55-a9f4498366ae} executeQuery: Code: 36. DB::Exception: Primary key must be a prefix of the sorting key, but its length: 2 is greater than the sorting key length: 1. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33142) (comment: 00754_alter_modify_order_by_replicated_zookeeper_long.sql) (query 15, line 29) (in query: /* Can't modyfy ORDER BY so that it is no longer a prefix of the PRIMARY KEY. */ ALTER TABLE summing_r1 MODIFY ORDER BY x;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b1188ad 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:720: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x000000003977579c 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3860: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003981e60c 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 08:59:45.230528 [ 9260 ] {} TCPHandler: Code: 36. DB::Exception: Primary key must be a prefix of the sorting key, but its length: 2 is greater than the sorting key length: 1. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b1188ad 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:720: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x000000003977579c 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3860: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003981e60c 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 08:59:46.289648 [ 9237 ] {11912a4a-26cb-4a9b-a050-349d36441ab1} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `a` in scope SELECT a AS b, b AS a. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51114) (comment: 02341_analyzer_aliases_basics.sql) (query 10, line 15) (in query: SELECT a AS b, b AS a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000303dd3a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032b465 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:59:46.299317 [ 9237 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `a` in scope SELECT a AS b, b AS a. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000303dd3a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032b465 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 08:59:47.637135 [ 9237 ] {8a3db1dd-4021-40ff-a371-95e4ad0716aa} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `b` in scope SELECT id + b AS id, id AS b FROM test_table. Maybe you meant: ['b']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51114) (comment: 02341_analyzer_aliases_basics.sql) (query 18, line 33) (in query: SELECT (id + b) AS id, id as b FROM test_table;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000303dd3a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032b465 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b6ae 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:59:47.644950 [ 9237 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `b` in scope SELECT id + b AS id, id AS b FROM test_table. Maybe you meant: ['b']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000303dd3a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032b465 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b6ae 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:59:48.044078 [ 9237 ] {7a3f6203-9341-4d5a-a1a9-c69ae8ea0cde} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `b` in scope SELECT ((1 + b) + 1) + id AS id, b AS c, id AS b FROM test_table. Maybe you meant: ['b']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51114) (comment: 02341_analyzer_aliases_basics.sql) (query 19, line 34) (in query: SELECT (1 + b + 1 + id) AS id, b as c, id as b FROM test_table;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000303dd3a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032b465 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b6ae 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1228: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030359022 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b6ae 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 2025.06.13 08:59:48.052809 [ 9237 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `b` in scope SELECT ((1 + b) + 1) + id AS id, b AS c, id AS b FROM test_table. Maybe you meant: ['b']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000303dd3a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032b465 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030358cd4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b6ae 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1228: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030359022 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b6ae 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 2025.06.13 08:59:52.757974 [ 9263 ] {6b618941-8b57-4589-b92a-585999d715f3} executeQuery: Code: 117. DB::Exception: Cannot parse text value of type Variant(Date) here: 42: In scope SELECT CAST('42', 'Variant(Date)') AS v, variantType(v). (INCORRECT_DATA) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51236) (comment: 03032_string_to_variant_cast.sql) (query 7, line 7) (in query: select CAST('42', 'Variant(Date)') as v, variantType(v);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&) @ 0x000000001ffa1a4d 4. ./build_docker/./src/DataTypes/Serializations/SerializationVariant.cpp:1060: DB::SerializationVariant::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f785b1d 5. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c1f7b0d 6. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c1f4e39 7. DB::detail::FunctionCast::createStringToVariantWrapper() const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c1f8df8 8. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c1f846e 9. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 10. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008bec782 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:59:52.826514 [ 9263 ] {} TCPHandler: Code: 117. DB::Exception: Cannot parse text value of type Variant(Date) here: 42: In scope SELECT CAST('42', 'Variant(Date)') AS v, variantType(v). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&) @ 0x000000001ffa1a4d 4. ./build_docker/./src/DataTypes/Serializations/SerializationVariant.cpp:1060: DB::SerializationVariant::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f785b1d 5. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c1f7b0d 6. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c1f4e39 7. DB::detail::FunctionCast::createStringToVariantWrapper() const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c1f8df8 8. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c1f846e 9. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 10. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008bec782 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:59:53.115739 [ 9261 ] {fbadffb1-85e3-4ce6-9844-4c522e87b5b1} executeQuery: Code: 42. DB::Exception: Number of arguments for function addDate doesn't match: passed 1, should be 2: In scope SELECT addDate(CAST('2022-05-07', 'Date')). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51254) (comment: 02834_add_sub_date_functions.sql) (query 8, line 11) (in query: SELECT addDate('2022-05-07'::Date);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:59:53.131176 [ 9261 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addDate doesn't match: passed 1, should be 2: In scope SELECT addDate(CAST('2022-05-07', 'Date')). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:59:53.205724 [ 9261 ] {0ead4471-9eec-47cb-8c7f-f4f8186ebc80} executeQuery: Code: 42. DB::Exception: Number of arguments for function addDate doesn't match: passed 3, should be 2: In scope SELECT addDate(CAST('2022-05-07', 'Date'), toIntervalMinute(5), 5). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51254) (comment: 02834_add_sub_date_functions.sql) (query 9, line 12) (in query: SELECT addDate('2022-05-07'::Date, INTERVAL 5 MINUTE, 5);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:59:53.214759 [ 9261 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addDate doesn't match: passed 3, should be 2: In scope SELECT addDate(CAST('2022-05-07', 'Date'), toIntervalMinute(5), 5). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:59:53.562024 [ 9261 ] {e3a12258-fa04-4a0e-a3a7-a0440ded749b} executeQuery: Code: 43. DB::Exception: Illegal type UInt8 of 2nd argument of function addDate. Should be an interval: In scope SELECT addDate(CAST('2022-05-07', 'Date'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51254) (comment: 02834_add_sub_date_functions.sql) (query 10, line 13) (in query: SELECT addDate('2022-05-07'::Date, 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::(anonymous namespace)::FunctionOpDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a247b11 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:59:53.581426 [ 9261 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type UInt8 of 2nd argument of function addDate. Should be an interval: In scope SELECT addDate(CAST('2022-05-07', 'Date'), 10). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::(anonymous namespace)::FunctionOpDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a247b11 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:59:53.921995 [ 9261 ] {c43f7deb-e0af-47b8-8c71-902d8228843b} executeQuery: Code: 43. DB::Exception: Illegal type Float64 of 1st argument of function addDate. Should be a date, a date with time or a string: In scope SELECT addDate(1.2, toIntervalMinute(5)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51254) (comment: 02834_add_sub_date_functions.sql) (query 11, line 14) (in query: SELECT addDate(1.2, INTERVAL 5 MINUTE);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::(anonymous namespace)::FunctionOpDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a247ea6 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:59:54.110656 [ 9261 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Float64 of 1st argument of function addDate. Should be a date, a date with time or a string: In scope SELECT addDate(1.2, toIntervalMinute(5)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::(anonymous namespace)::FunctionOpDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a247ea6 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:59:55.229455 [ 9261 ] {0cfc501b-b12d-4323-9976-d5bc2342c704} executeQuery: Code: 42. DB::Exception: Number of arguments for function subDate doesn't match: passed 1, should be 2: In scope SELECT subDate(CAST('2022-05-07', 'Date')). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51254) (comment: 02834_add_sub_date_functions.sql) (query 19, line 26) (in query: SELECT subDate('2022-05-07'::Date);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:59:55.237852 [ 9261 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subDate doesn't match: passed 1, should be 2: In scope SELECT subDate(CAST('2022-05-07', 'Date')). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:59:55.297365 [ 9261 ] {f240adee-dd3f-4287-af53-5d3f02b90d46} executeQuery: Code: 42. DB::Exception: Number of arguments for function subDate doesn't match: passed 3, should be 2: In scope SELECT subDate(CAST('2022-05-07', 'Date'), toIntervalMinute(5), 5). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51254) (comment: 02834_add_sub_date_functions.sql) (query 20, line 27) (in query: SELECT subDate('2022-05-07'::Date, INTERVAL 5 MINUTE, 5);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:59:55.314964 [ 9261 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subDate doesn't match: passed 3, should be 2: In scope SELECT subDate(CAST('2022-05-07', 'Date'), toIntervalMinute(5), 5). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 08:59:55.650976 [ 9261 ] {c50cb846-d2b6-4add-8ddf-00a2ae6c0b50} executeQuery: Code: 43. DB::Exception: Illegal type UInt8 of 2nd argument of function subDate. Should be an interval: In scope SELECT subDate(CAST('2022-05-07', 'Date'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51254) (comment: 02834_add_sub_date_functions.sql) (query 21, line 28) (in query: SELECT subDate('2022-05-07'::Date, 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::(anonymous namespace)::FunctionOpDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a24a311 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:59:55.665073 [ 9261 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type UInt8 of 2nd argument of function subDate. Should be an interval: In scope SELECT subDate(CAST('2022-05-07', 'Date'), 10). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::(anonymous namespace)::FunctionOpDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a24a311 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:59:55.984423 [ 9261 ] {6133db05-8250-4266-b555-c8735b0be529} executeQuery: Code: 43. DB::Exception: Illegal type Float64 of 1st argument of function subDate. Should be a date, a date with time or a string: In scope SELECT subDate(1.2, toIntervalMinute(5)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51254) (comment: 02834_add_sub_date_functions.sql) (query 22, line 29) (in query: SELECT subDate(1.2, INTERVAL 5 MINUTE);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::(anonymous namespace)::FunctionOpDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a24a68f 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:59:56.002047 [ 9261 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Float64 of 1st argument of function subDate. Should be a date, a date with time or a string: In scope SELECT subDate(1.2, toIntervalMinute(5)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::(anonymous namespace)::FunctionOpDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a24a68f 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 08:59:56.081579 [ 15844 ] {a4d0c073-8547-4db9-9934-b485984593e5} executeQuery: Code: 70. DB::Exception: Unsupported data type in conversion function: In scope SELECT toIntervalSecond(now64()). (CANNOT_CONVERT_TYPE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58644) (comment: 01291_unsupported_conversion_from_decimal.sql) (query 1, line 1) (in query: SELECT toIntervalSecond(now64());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000008f2262b 5. bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x0000000008f0f199 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000008e38fa3 7. DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008f0a1dd 8. DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008f08a82 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:59:56.089434 [ 15844 ] {} TCPHandler: Code: 70. DB::Exception: Unsupported data type in conversion function: In scope SELECT toIntervalSecond(now64()). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000008f2262b 5. bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x0000000008f0f199 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000008e38fa3 7. DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008f0a1dd 8. DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008f08a82 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:59:56.443335 [ 15844 ] {1d37be42-9e7e-4fc1-a039-b1833229c14d} executeQuery: Code: 70. DB::Exception: Unsupported data type in conversion function: In scope SELECT CAST(now64(), 'IntervalSecond'). (CANNOT_CONVERT_TYPE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58644) (comment: 01291_unsupported_conversion_from_decimal.sql) (query 2, line 2) (in query: SELECT CAST(now64() AS IntervalSecond);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000008f2262b 5. bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x0000000008f0f199 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000008e38fa3 7. DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008f0a1dd 8. DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008f08a82 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff69df 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c25d2a9 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 16. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008bec782 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 18. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 2025.06.13 08:59:56.458538 [ 15844 ] {} TCPHandler: Code: 70. DB::Exception: Unsupported data type in conversion function: In scope SELECT CAST(now64(), 'IntervalSecond'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000008f2262b 5. bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x0000000008f0f199 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000008e38fa3 7. DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008f0a1dd 8. DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008f08a82 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff69df 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c25d2a9 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 16. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008bec782 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 18. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 2025.06.13 08:59:56.506045 [ 15844 ] {adb5516c-6dc3-45f3-88ae-843738e195f5} executeQuery: Code: 70. DB::Exception: Unsupported data type in conversion function: In scope SELECT toIntervalSecond(now64()). (CANNOT_CONVERT_TYPE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58644) (comment: 01291_unsupported_conversion_from_decimal.sql) (query 3, line 4) (in query: SELECT toIntervalSecond(now64());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000008f2262b 5. bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x0000000008f0f199 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000008e38fa3 7. DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008f0a1dd 8. DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008f08a82 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:59:56.519536 [ 15844 ] {} TCPHandler: Code: 70. DB::Exception: Unsupported data type in conversion function: In scope SELECT toIntervalSecond(now64()). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000008f2262b 5. bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x0000000008f0f199 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000008e38fa3 7. DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008f0a1dd 8. DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008f08a82 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 08:59:56.574389 [ 15844 ] {0dc59673-4683-4a56-aa6a-861052b6fadf} executeQuery: Code: 70. DB::Exception: Unsupported data type in conversion function: In scope SELECT CAST(now64(), 'IntervalSecond'). (CANNOT_CONVERT_TYPE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58644) (comment: 01291_unsupported_conversion_from_decimal.sql) (query 4, line 5) (in query: SELECT CAST(now64() AS IntervalSecond);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000008f2262b 5. bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x0000000008f0f199 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000008e38fa3 7. DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008f0a1dd 8. DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008f08a82 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff69df 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c25d2a9 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 16. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008bec782 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 18. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 2025.06.13 08:59:56.583957 [ 15844 ] {} TCPHandler: Code: 70. DB::Exception: Unsupported data type in conversion function: In scope SELECT CAST(now64(), 'IntervalSecond'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000008f2262b 5. bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x0000000008f0f199 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000008e38fa3 7. DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008f0a1dd 8. DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008f08a82 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff69df 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c25d2a9 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c1c1338 16. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008bec782 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 18. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff0855 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 2025.06.13 08:59:58.038574 [ 9224 ] {a9eb786d-c7aa-420b-a423-0c21220a5b36} executeQuery: Code: 36. DB::Exception: Table TTL is not allowed for MergeTree in old syntax. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58690) (comment: 01713_table_ttl_old_syntax_zookeeper.sql) (query 3, line 6) (in query: CREATE TABLE ttl_table ( date Date, value UInt64 ) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test_01713_table_ttl', '1', date, date, 8192) TTL date + INTERVAL 2 MONTH;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:843: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a383d8e 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:59:58.152509 [ 9224 ] {} TCPHandler: Code: 36. DB::Exception: Table TTL is not allowed for MergeTree in old syntax. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:843: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a383d8e 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:59:58.430365 [ 9224 ] {b62f240c-bb3e-426f-9757-8735cb70beed} executeQuery: Code: 42. DB::Exception: With extended storage definition syntax storage ReplicatedMergeTree requires 0 to 2 parameters: [path in ZooKeeper], [replica name] Syntax for the MergeTree table engine: CREATE TABLE [IF NOT EXISTS] [db.]table_name [ON CLUSTER cluster] ( name1 [type1] [DEFAULT|MATERIALIZED|ALIAS expr1] [TTL expr1], name2 [type2] [DEFAULT|MATERIALIZED|ALIAS expr2] [TTL expr2], ... INDEX index_name1 expr1 TYPE type1(...) [GRANULARITY value1], INDEX index_name2 expr2 TYPE type2(...) [GRANULARITY value2] ) ENGINE = MergeTree() ORDER BY expr [PARTITION BY expr] [PRIMARY KEY expr] [SAMPLE BY expr] [TTL expr [DELETE|TO DISK 'xxx'|TO VOLUME 'xxx'], ...] [SETTINGS name=value, ...] [COMMENT 'comment'] See details in documentation: https://clickhouse.com/docs/engines/table-engines/mergetree-family/mergetree/. Other engines of the family support different syntax, see details in the corresponding documentation topics. If you use the Replicated version of engines, see https://clickhouse.com/docs/engines/table-engines/mergetree-family/replication/. . (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58690) (comment: 01713_table_ttl_old_syntax_zookeeper.sql) (query 4, line 14) (in query: CREATE TABLE ttl_table (`date` Date, `value` UInt64) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test_01713_table_ttl', '1', date, date, 8192) PARTITION BY date SETTINGS index_granularity = 56977, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.7029475569725037, replace_long_file_name_to_hash = false, max_file_name_length = 116, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 89364168, compact_parts_max_granules_to_buffer = 115, compact_parts_merge_max_bytes_to_prefetch_part = 3500390, merge_max_block_size = 20158, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 9971818, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 23129, primary_key_compress_block_size = 64694, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&, char const* const&) @ 0x000000003a38a377 4. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:500: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a38344b 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:59:58.437800 [ 9224 ] {} TCPHandler: Code: 42. DB::Exception: With extended storage definition syntax storage ReplicatedMergeTree requires 0 to 2 parameters: [path in ZooKeeper], [replica name] Syntax for the MergeTree table engine: CREATE TABLE [IF NOT EXISTS] [db.]table_name [ON CLUSTER cluster] ( name1 [type1] [DEFAULT|MATERIALIZED|ALIAS expr1] [TTL expr1], name2 [type2] [DEFAULT|MATERIALIZED|ALIAS expr2] [TTL expr2], ... INDEX index_name1 expr1 TYPE type1(...) [GRANULARITY value1], INDEX index_name2 expr2 TYPE type2(...) [GRANULARITY value2] ) ENGINE = MergeTree() ORDER BY expr [PARTITION BY expr] [PRIMARY KEY expr] [SAMPLE BY expr] [TTL expr [DELETE|TO DISK 'xxx'|TO VOLUME 'xxx'], ...] [SETTINGS name=value, ...] [COMMENT 'comment'] See details in documentation: https://clickhouse.com/docs/engines/table-engines/mergetree-family/mergetree/. Other engines of the family support different syntax, see details in the corresponding documentation topics. If you use the Replicated version of engines, see https://clickhouse.com/docs/engines/table-engines/mergetree-family/replication/. . (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&, char const* const&) @ 0x000000003a38a377 4. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:500: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a38344b 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:59:58.510480 [ 9224 ] {c7bde679-44da-419f-b136-b822e12853a0} executeQuery: Code: 42. DB::Exception: With extended storage definition syntax storage ReplicatedMergeTree requires 0 to 2 parameters: [path in ZooKeeper], [replica name] Syntax for the MergeTree table engine: CREATE TABLE [IF NOT EXISTS] [db.]table_name [ON CLUSTER cluster] ( name1 [type1] [DEFAULT|MATERIALIZED|ALIAS expr1] [TTL expr1], name2 [type2] [DEFAULT|MATERIALIZED|ALIAS expr2] [TTL expr2], ... INDEX index_name1 expr1 TYPE type1(...) [GRANULARITY value1], INDEX index_name2 expr2 TYPE type2(...) [GRANULARITY value2] ) ENGINE = MergeTree() ORDER BY expr [PARTITION BY expr] [PRIMARY KEY expr] [SAMPLE BY expr] [TTL expr [DELETE|TO DISK 'xxx'|TO VOLUME 'xxx'], ...] [SETTINGS name=value, ...] [COMMENT 'comment'] See details in documentation: https://clickhouse.com/docs/engines/table-engines/mergetree-family/mergetree/. Other engines of the family support different syntax, see details in the corresponding documentation topics. If you use the Replicated version of engines, see https://clickhouse.com/docs/engines/table-engines/mergetree-family/replication/. . (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58690) (comment: 01713_table_ttl_old_syntax_zookeeper.sql) (query 5, line 22) (in query: CREATE TABLE ttl_table (`date` Date, `value` UInt64) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test_01713_table_ttl', '1', date, date, 8192) ORDER BY value SETTINGS index_granularity = 56977, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.7029475569725037, replace_long_file_name_to_hash = false, max_file_name_length = 116, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 89364168, compact_parts_max_granules_to_buffer = 115, compact_parts_merge_max_bytes_to_prefetch_part = 3500390, merge_max_block_size = 20158, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 9971818, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 23129, primary_key_compress_block_size = 64694, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&, char const* const&) @ 0x000000003a38a377 4. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:500: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a38344b 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 08:59:58.534952 [ 9224 ] {} TCPHandler: Code: 42. DB::Exception: With extended storage definition syntax storage ReplicatedMergeTree requires 0 to 2 parameters: [path in ZooKeeper], [replica name] Syntax for the MergeTree table engine: CREATE TABLE [IF NOT EXISTS] [db.]table_name [ON CLUSTER cluster] ( name1 [type1] [DEFAULT|MATERIALIZED|ALIAS expr1] [TTL expr1], name2 [type2] [DEFAULT|MATERIALIZED|ALIAS expr2] [TTL expr2], ... INDEX index_name1 expr1 TYPE type1(...) [GRANULARITY value1], INDEX index_name2 expr2 TYPE type2(...) [GRANULARITY value2] ) ENGINE = MergeTree() ORDER BY expr [PARTITION BY expr] [PRIMARY KEY expr] [SAMPLE BY expr] [TTL expr [DELETE|TO DISK 'xxx'|TO VOLUME 'xxx'], ...] [SETTINGS name=value, ...] [COMMENT 'comment'] See details in documentation: https://clickhouse.com/docs/engines/table-engines/mergetree-family/mergetree/. Other engines of the family support different syntax, see details in the corresponding documentation topics. If you use the Replicated version of engines, see https://clickhouse.com/docs/engines/table-engines/mergetree-family/replication/. . (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&, char const* const&) @ 0x000000003a38a377 4. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:500: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a38344b 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:00:09.948254 [ 24872 ] {44b5e18e-f627-4806-be26-5d8621aef264} executeQuery: Code: 290. DB::Exception: Maximum limit of 3 projection(s) exceeded. (LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59332) (comment: 02934_merge_tree_max_projections.sql) (query 6, line 10) (in query: ALTER TABLE test_max_mt_projections_alter ADD PROJECTION p4 (SELECT c2, c3 ORDER BY c2, c3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000ac4b38a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:838: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000039778fe8 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3860: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003981e60c 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:00:09.966868 [ 24872 ] {} TCPHandler: Code: 290. DB::Exception: Maximum limit of 3 projection(s) exceeded. (LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000ac4b38a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:838: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000039778fe8 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3860: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003981e60c 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:00:11.519157 [ 24872 ] {5a395230-6bf3-4560-a3da-d0a1bbc052fd} executeQuery: Code: 290. DB::Exception: Maximum limit of 1 projection(s) exceeded. (LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59332) (comment: 02934_merge_tree_max_projections.sql) (query 11, line 20) (in query: CREATE TABLE test_max_mt_projections_create (`c1` UInt32, `c2` UInt32, PROJECTION p1 (SELECT c1, c2 ORDER BY c2), PROJECTION p2 (SELECT c2 ORDER BY c2)) ENGINE = MergeTree ORDER BY c1 SETTINGS max_projections = 1, index_granularity = 47091, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.7458067536354065, replace_long_file_name_to_hash = false, max_file_name_length = 12, min_bytes_for_full_part_storage = 345290072, compact_parts_max_bytes_to_buffer = 394710168, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 30962968, merge_max_block_size = 6803, old_parts_lifetime = 296., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 860015, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 3383064261, index_granularity_bytes = 4743566, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 27768, primary_key_compress_block_size = 92562, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000ac4b38a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:838: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000039778fe8 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:869: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000003975fc87 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:517: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000003975c601 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a38dc5f 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a38d037 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37f002 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 09:00:11.534881 [ 24872 ] {} TCPHandler: Code: 290. DB::Exception: Maximum limit of 1 projection(s) exceeded. (LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000ac4b38a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:838: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000039778fe8 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:869: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000003975fc87 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:517: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000003975c601 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a38dc5f 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a38d037 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37f002 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 09:00:11.734115 [ 24872 ] {2435d8a8-1421-4f89-b1bf-bb0f8706cea2} executeQuery: Code: 290. DB::Exception: Maximum limit of 0 projection(s) exceeded. (LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59332) (comment: 02934_merge_tree_max_projections.sql) (query 12, line 26) (in query: CREATE TABLE test_max_mt_projections_create (`c1` UInt32, `c2` UInt32, PROJECTION p (SELECT c1, c2 ORDER BY c2)) ENGINE = MergeTree ORDER BY c1 SETTINGS max_projections = 0, index_granularity = 47091, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.7458067536354065, replace_long_file_name_to_hash = false, max_file_name_length = 12, min_bytes_for_full_part_storage = 345290072, compact_parts_max_bytes_to_buffer = 394710168, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 30962968, merge_max_block_size = 6803, old_parts_lifetime = 296., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 860015, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 3383064261, index_granularity_bytes = 4743566, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 27768, primary_key_compress_block_size = 92562, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000ac4b38a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:838: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000039778fe8 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:869: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000003975fc87 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:517: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000003975c601 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a38dc5f 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a38d037 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37f002 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 09:00:11.741482 [ 24872 ] {} TCPHandler: Code: 290. DB::Exception: Maximum limit of 0 projection(s) exceeded. (LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000ac4b38a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:838: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000039778fe8 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:869: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000003975fc87 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:517: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000003975c601 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a38dc5f 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a38d037 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37f002 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 09:00:12.130884 [ 24872 ] {64a01435-9003-4eaf-9e3f-206580abf116} executeQuery: Code: 290. DB::Exception: Maximum limit of 1 projection(s) exceeded. (LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59332) (comment: 02934_merge_tree_max_projections.sql) (query 14, line 36) (in query: ALTER TABLE test_max_mt_projections_create ADD PROJECTION p2 (SELECT c2 ORDER BY c2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000ac4b38a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:838: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000039778fe8 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3860: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003981e60c 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:00:12.140709 [ 24872 ] {} TCPHandler: Code: 290. DB::Exception: Maximum limit of 1 projection(s) exceeded. (LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000ac4b38a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:838: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000039778fe8 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3860: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003981e60c 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:00:14.934462 [ 15837 ] {01572_kill_window_function-test_ajbi3vy4} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37258) (comment: 01572_kill_window_function.sh) (query 1, line 1) (in query: SELECT sum(number) OVER (PARTITION BY number % 10 ORDER BY number DESC NULLS FIRST ROWS BETWEEN CURRENT ROW AND 99999 FOLLOWING) FROM numbers(0, 10000000) format Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032e79999 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032e796c3 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032e7ac23 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b0aef87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae681 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:00:14.996821 [ 15837 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032e79999 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032e796c3 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032e7ac23 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b0aef87 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae681 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:00:15.607879 [ 34536 ] {4dccda69-38ab-475d-a891-8216a37e3015} ConnectionPoolWithFailover: There is no table `test_3qcuynmr`.`underlying` on server: localhost:9000 2025.06.13 09:00:15.815987 [ 24858 ] {4dccda69-38ab-475d-a891-8216a37e3015} executeQuery: Code: 279. DB::NetException: All connection tries failed. Log: There is no table `test_3qcuynmr`.`underlying` on server: localhost:9000 : While sending /var/lib/clickhouse/store/f3e/f3ef1c4e-3079-411a-bba8-a56f42357a62/shard1_replica1/1.bin. (ALL_CONNECTION_TRIES_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37300) (comment: 02537_distributed_loosing_files_after_exception.gen.sql) (query 8, line 15) (in query: SYSTEM FLUSH DISTRIBUTED dist;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038e302d6 3. ./src/Common/PoolWithFailoverBase.h:346: PoolWithFailoverBase::getMany(unsigned long, unsigned long, unsigned long, unsigned long, bool, bool, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::function const&) @ 0x000000003a9f4a3c 4. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:236: DB::ConnectionPoolWithFailover::getManyImpl(DB::Settings const&, DB::PoolMode, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::optional, std::function, bool) @ 0x000000003a9ec9ca 5. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:180: DB::ConnectionPoolWithFailover::getManyCheckedForInsert(DB::ConnectionTimeouts const&, DB::Settings const&, DB::PoolMode, DB::QualifiedTableName const&) @ 0x000000003a9eda00 6. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:434: DB::DistributedAsyncInsertDirectoryQueue::processFile(String&, DB::SettingsChanges const&) @ 0x000000003935edfb 7. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:396: DB::DistributedAsyncInsertDirectoryQueue::processFiles(bool, DB::SettingsChanges const&) @ 0x000000003934eb6b 8. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:173: DB::DistributedAsyncInsertDirectoryQueue::flushAllData(DB::SettingsChanges const&) @ 0x000000003934e3aa 9. ./build_docker/./src/Storages/StorageDistributed.cpp:1768: void std::__function::__policy_invoker::__call_impl[abi:ne190107], DB::SettingsChanges const&, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000383ac38e 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026c07c0a 11. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x0000000026c0782d 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000026c0755f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:00:16.017009 [ 24858 ] {} TCPHandler: Code: 279. DB::NetException: All connection tries failed. Log: There is no table `test_3qcuynmr`.`underlying` on server: localhost:9000 : While sending /var/lib/clickhouse/store/f3e/f3ef1c4e-3079-411a-bba8-a56f42357a62/shard1_replica1/1.bin. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038e302d6 3. ./src/Common/PoolWithFailoverBase.h:346: PoolWithFailoverBase::getMany(unsigned long, unsigned long, unsigned long, unsigned long, bool, bool, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::function const&) @ 0x000000003a9f4a3c 4. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:236: DB::ConnectionPoolWithFailover::getManyImpl(DB::Settings const&, DB::PoolMode, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::optional, std::function, bool) @ 0x000000003a9ec9ca 5. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:180: DB::ConnectionPoolWithFailover::getManyCheckedForInsert(DB::ConnectionTimeouts const&, DB::Settings const&, DB::PoolMode, DB::QualifiedTableName const&) @ 0x000000003a9eda00 6. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:434: DB::DistributedAsyncInsertDirectoryQueue::processFile(String&, DB::SettingsChanges const&) @ 0x000000003935edfb 7. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:396: DB::DistributedAsyncInsertDirectoryQueue::processFiles(bool, DB::SettingsChanges const&) @ 0x000000003934eb6b 8. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:173: DB::DistributedAsyncInsertDirectoryQueue::flushAllData(DB::SettingsChanges const&) @ 0x000000003934e3aa 9. ./build_docker/./src/Storages/StorageDistributed.cpp:1768: void std::__function::__policy_invoker::__call_impl[abi:ne190107], DB::SettingsChanges const&, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000383ac38e 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026c07c0a 11. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x0000000026c0782d 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000026c0755f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x0000000026c052d4 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1766: DB::StorageDistributed::flushClusterNodesAllDataImpl(std::shared_ptr, DB::SettingsChanges const&, bool) @ 0x000000003839e496 6. ./build_docker/./src/Storages/StorageDistributed.cpp:1738: DB::StorageDistributed::flushClusterNodesAllData(std::shared_ptr, DB::SettingsChanges const&) @ 0x00000000383a0d34 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1389: DB::InterpreterSystemQuery::flushDistributed(DB::ASTSystemQuery&) @ 0x000000003380f8d1 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:776: DB::InterpreterSystemQuery::execute() @ 0x00000000337e1268 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:00:16.148973 [ 34132 ] {da59da92-558e-40a2-aea3-35503f3c4e75} ConnectionPoolWithFailover: There is no table `test_3qcuynmr`.`underlying` on server: localhost:9000 2025.06.13 09:00:16.335950 [ 24858 ] {da59da92-558e-40a2-aea3-35503f3c4e75} executeQuery: Code: 279. DB::NetException: All connection tries failed. Log: There is no table `test_3qcuynmr`.`underlying` on server: localhost:9000 : While sending /var/lib/clickhouse/store/f3e/f3ef1c4e-3079-411a-bba8-a56f42357a62/shard1_replica1/1.bin. (ALL_CONNECTION_TRIES_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37300) (comment: 02537_distributed_loosing_files_after_exception.gen.sql) (query 9, line 16) (in query: -- check the second since after using queue it may got lost from it SYSTEM FLUSH DISTRIBUTED dist;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038e302d6 3. ./src/Common/PoolWithFailoverBase.h:346: PoolWithFailoverBase::getMany(unsigned long, unsigned long, unsigned long, unsigned long, bool, bool, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::function const&) @ 0x000000003a9f4a3c 4. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:236: DB::ConnectionPoolWithFailover::getManyImpl(DB::Settings const&, DB::PoolMode, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::optional, std::function, bool) @ 0x000000003a9ec9ca 5. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:180: DB::ConnectionPoolWithFailover::getManyCheckedForInsert(DB::ConnectionTimeouts const&, DB::Settings const&, DB::PoolMode, DB::QualifiedTableName const&) @ 0x000000003a9eda00 6. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:434: DB::DistributedAsyncInsertDirectoryQueue::processFile(String&, DB::SettingsChanges const&) @ 0x000000003935edfb 7. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:393: DB::DistributedAsyncInsertDirectoryQueue::processFiles(bool, DB::SettingsChanges const&) @ 0x000000003934ea75 8. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:173: DB::DistributedAsyncInsertDirectoryQueue::flushAllData(DB::SettingsChanges const&) @ 0x000000003934e3aa 9. ./build_docker/./src/Storages/StorageDistributed.cpp:1768: void std::__function::__policy_invoker::__call_impl[abi:ne190107], DB::SettingsChanges const&, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000383ac38e 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026c07c0a 11. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x0000000026c0782d 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000026c0755f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:00:16.353813 [ 24858 ] {} TCPHandler: Code: 279. DB::NetException: All connection tries failed. Log: There is no table `test_3qcuynmr`.`underlying` on server: localhost:9000 : While sending /var/lib/clickhouse/store/f3e/f3ef1c4e-3079-411a-bba8-a56f42357a62/shard1_replica1/1.bin. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038e302d6 3. ./src/Common/PoolWithFailoverBase.h:346: PoolWithFailoverBase::getMany(unsigned long, unsigned long, unsigned long, unsigned long, bool, bool, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::function const&) @ 0x000000003a9f4a3c 4. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:236: DB::ConnectionPoolWithFailover::getManyImpl(DB::Settings const&, DB::PoolMode, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::optional, std::function, bool) @ 0x000000003a9ec9ca 5. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:180: DB::ConnectionPoolWithFailover::getManyCheckedForInsert(DB::ConnectionTimeouts const&, DB::Settings const&, DB::PoolMode, DB::QualifiedTableName const&) @ 0x000000003a9eda00 6. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:434: DB::DistributedAsyncInsertDirectoryQueue::processFile(String&, DB::SettingsChanges const&) @ 0x000000003935edfb 7. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:393: DB::DistributedAsyncInsertDirectoryQueue::processFiles(bool, DB::SettingsChanges const&) @ 0x000000003934ea75 8. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:173: DB::DistributedAsyncInsertDirectoryQueue::flushAllData(DB::SettingsChanges const&) @ 0x000000003934e3aa 9. ./build_docker/./src/Storages/StorageDistributed.cpp:1768: void std::__function::__policy_invoker::__call_impl[abi:ne190107], DB::SettingsChanges const&, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000383ac38e 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026c07c0a 11. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x0000000026c0782d 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000026c0755f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x0000000026c052d4 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1766: DB::StorageDistributed::flushClusterNodesAllDataImpl(std::shared_ptr, DB::SettingsChanges const&, bool) @ 0x000000003839e496 6. ./build_docker/./src/Storages/StorageDistributed.cpp:1738: DB::StorageDistributed::flushClusterNodesAllData(std::shared_ptr, DB::SettingsChanges const&) @ 0x00000000383a0d34 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1389: DB::InterpreterSystemQuery::flushDistributed(DB::ASTSystemQuery&) @ 0x000000003380f8d1 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:776: DB::InterpreterSystemQuery::execute() @ 0x00000000337e1268 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:00:18.475468 [ 37795 ] {048535a6-520f-49c2-a050-1c5120d1bcfb} ConnectionPoolWithFailover: There is no table `test_3qcuynmr`.`underlying` on server: localhost:9000 2025.06.13 09:00:18.715219 [ 24858 ] {048535a6-520f-49c2-a050-1c5120d1bcfb} executeQuery: Code: 279. DB::NetException: All connection tries failed. Log: There is no table `test_3qcuynmr`.`underlying` on server: localhost:9000 : While sending a batch of 1 files, files: /var/lib/clickhouse/store/eae/eaeeef14-4712-4362-9d60-ac3b24ba202c/shard1_replica1/2.bin. (ALL_CONNECTION_TRIES_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37300) (comment: 02537_distributed_loosing_files_after_exception.gen.sql) (query 23, line 46) (in query: SYSTEM FLUSH DISTRIBUTED dist;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038e302d6 3. ./src/Common/PoolWithFailoverBase.h:346: PoolWithFailoverBase::getMany(unsigned long, unsigned long, unsigned long, unsigned long, bool, bool, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::function const&) @ 0x000000003a9f4a3c 4. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:236: DB::ConnectionPoolWithFailover::getManyImpl(DB::Settings const&, DB::PoolMode, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::optional, std::function, bool) @ 0x000000003a9ec9ca 5. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:180: DB::ConnectionPoolWithFailover::getManyCheckedForInsert(DB::ConnectionTimeouts const&, DB::Settings const&, DB::PoolMode, DB::QualifiedTableName const&) @ 0x000000003a9eda00 6. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:266: DB::DistributedAsyncInsertBatch::sendBatch(DB::SettingsChanges const&) @ 0x000000003937951a 7. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:101: DB::DistributedAsyncInsertBatch::send(DB::SettingsChanges const&, bool) @ 0x0000000039371b76 8. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:639: DB::DistributedAsyncInsertDirectoryQueue::processFilesWithBatching(bool, DB::SettingsChanges const&) @ 0x000000003935bb6d 9. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:388: DB::DistributedAsyncInsertDirectoryQueue::processFiles(bool, DB::SettingsChanges const&) @ 0x000000003934e938 10. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:173: DB::DistributedAsyncInsertDirectoryQueue::flushAllData(DB::SettingsChanges const&) @ 0x000000003934e3aa 11. ./build_docker/./src/Storages/StorageDistributed.cpp:1768: void std::__function::__policy_invoker::__call_impl[abi:ne190107], DB::SettingsChanges const&, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000383ac38e 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026c07c0a 13. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x0000000026c0782d 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000026c0755f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 09:00:18.722010 [ 24858 ] {} TCPHandler: Code: 279. DB::NetException: All connection tries failed. Log: There is no table `test_3qcuynmr`.`underlying` on server: localhost:9000 : While sending a batch of 1 files, files: /var/lib/clickhouse/store/eae/eaeeef14-4712-4362-9d60-ac3b24ba202c/shard1_replica1/2.bin. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038e302d6 3. ./src/Common/PoolWithFailoverBase.h:346: PoolWithFailoverBase::getMany(unsigned long, unsigned long, unsigned long, unsigned long, bool, bool, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::function const&) @ 0x000000003a9f4a3c 4. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:236: DB::ConnectionPoolWithFailover::getManyImpl(DB::Settings const&, DB::PoolMode, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::optional, std::function, bool) @ 0x000000003a9ec9ca 5. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:180: DB::ConnectionPoolWithFailover::getManyCheckedForInsert(DB::ConnectionTimeouts const&, DB::Settings const&, DB::PoolMode, DB::QualifiedTableName const&) @ 0x000000003a9eda00 6. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:266: DB::DistributedAsyncInsertBatch::sendBatch(DB::SettingsChanges const&) @ 0x000000003937951a 7. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:101: DB::DistributedAsyncInsertBatch::send(DB::SettingsChanges const&, bool) @ 0x0000000039371b76 8. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:639: DB::DistributedAsyncInsertDirectoryQueue::processFilesWithBatching(bool, DB::SettingsChanges const&) @ 0x000000003935bb6d 9. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:388: DB::DistributedAsyncInsertDirectoryQueue::processFiles(bool, DB::SettingsChanges const&) @ 0x000000003934e938 10. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:173: DB::DistributedAsyncInsertDirectoryQueue::flushAllData(DB::SettingsChanges const&) @ 0x000000003934e3aa 11. ./build_docker/./src/Storages/StorageDistributed.cpp:1768: void std::__function::__policy_invoker::__call_impl[abi:ne190107], DB::SettingsChanges const&, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000383ac38e 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026c07c0a 13. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x0000000026c0782d 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000026c0755f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x0000000026c052d4 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1766: DB::StorageDistributed::flushClusterNodesAllDataImpl(std::shared_ptr, DB::SettingsChanges const&, bool) @ 0x000000003839e496 6. ./build_docker/./src/Storages/StorageDistributed.cpp:1738: DB::StorageDistributed::flushClusterNodesAllData(std::shared_ptr, DB::SettingsChanges const&) @ 0x00000000383a0d34 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1389: DB::InterpreterSystemQuery::flushDistributed(DB::ASTSystemQuery&) @ 0x000000003380f8d1 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:776: DB::InterpreterSystemQuery::execute() @ 0x00000000337e1268 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:00:18.812141 [ 1381 ] {f14061cd-d929-40c5-a5cc-9686e673d077} ConnectionPoolWithFailover: There is no table `test_3qcuynmr`.`underlying` on server: localhost:9000 2025.06.13 09:00:18.989664 [ 24858 ] {f14061cd-d929-40c5-a5cc-9686e673d077} executeQuery: Code: 279. DB::NetException: All connection tries failed. Log: There is no table `test_3qcuynmr`.`underlying` on server: localhost:9000 : While sending a batch of 1 files, files: /var/lib/clickhouse/store/eae/eaeeef14-4712-4362-9d60-ac3b24ba202c/shard1_replica1//2.bin. (ALL_CONNECTION_TRIES_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37300) (comment: 02537_distributed_loosing_files_after_exception.gen.sql) (query 24, line 47) (in query: -- check the second since after using queue it may got lost from it SYSTEM FLUSH DISTRIBUTED dist;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038e302d6 3. ./src/Common/PoolWithFailoverBase.h:346: PoolWithFailoverBase::getMany(unsigned long, unsigned long, unsigned long, unsigned long, bool, bool, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::function const&) @ 0x000000003a9f4a3c 4. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:236: DB::ConnectionPoolWithFailover::getManyImpl(DB::Settings const&, DB::PoolMode, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::optional, std::function, bool) @ 0x000000003a9ec9ca 5. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:180: DB::ConnectionPoolWithFailover::getManyCheckedForInsert(DB::ConnectionTimeouts const&, DB::Settings const&, DB::PoolMode, DB::QualifiedTableName const&) @ 0x000000003a9eda00 6. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:266: DB::DistributedAsyncInsertBatch::sendBatch(DB::SettingsChanges const&) @ 0x000000003937951a 7. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:101: DB::DistributedAsyncInsertBatch::send(DB::SettingsChanges const&, bool) @ 0x0000000039371b76 8. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:552: DB::DistributedAsyncInsertDirectoryQueue::processFilesWithBatching(bool, DB::SettingsChanges const&) @ 0x00000000393552e6 9. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:388: DB::DistributedAsyncInsertDirectoryQueue::processFiles(bool, DB::SettingsChanges const&) @ 0x000000003934e938 10. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:173: DB::DistributedAsyncInsertDirectoryQueue::flushAllData(DB::SettingsChanges const&) @ 0x000000003934e3aa 11. ./build_docker/./src/Storages/StorageDistributed.cpp:1768: void std::__function::__policy_invoker::__call_impl[abi:ne190107], DB::SettingsChanges const&, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000383ac38e 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026c07c0a 13. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x0000000026c0782d 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000026c0755f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 09:00:18.997610 [ 24858 ] {} TCPHandler: Code: 279. DB::NetException: All connection tries failed. Log: There is no table `test_3qcuynmr`.`underlying` on server: localhost:9000 : While sending a batch of 1 files, files: /var/lib/clickhouse/store/eae/eaeeef14-4712-4362-9d60-ac3b24ba202c/shard1_replica1//2.bin. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038e302d6 3. ./src/Common/PoolWithFailoverBase.h:346: PoolWithFailoverBase::getMany(unsigned long, unsigned long, unsigned long, unsigned long, bool, bool, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::function const&) @ 0x000000003a9f4a3c 4. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:236: DB::ConnectionPoolWithFailover::getManyImpl(DB::Settings const&, DB::PoolMode, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::optional, std::function, bool) @ 0x000000003a9ec9ca 5. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:180: DB::ConnectionPoolWithFailover::getManyCheckedForInsert(DB::ConnectionTimeouts const&, DB::Settings const&, DB::PoolMode, DB::QualifiedTableName const&) @ 0x000000003a9eda00 6. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:266: DB::DistributedAsyncInsertBatch::sendBatch(DB::SettingsChanges const&) @ 0x000000003937951a 7. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:101: DB::DistributedAsyncInsertBatch::send(DB::SettingsChanges const&, bool) @ 0x0000000039371b76 8. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:552: DB::DistributedAsyncInsertDirectoryQueue::processFilesWithBatching(bool, DB::SettingsChanges const&) @ 0x00000000393552e6 9. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:388: DB::DistributedAsyncInsertDirectoryQueue::processFiles(bool, DB::SettingsChanges const&) @ 0x000000003934e938 10. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:173: DB::DistributedAsyncInsertDirectoryQueue::flushAllData(DB::SettingsChanges const&) @ 0x000000003934e3aa 11. ./build_docker/./src/Storages/StorageDistributed.cpp:1768: void std::__function::__policy_invoker::__call_impl[abi:ne190107], DB::SettingsChanges const&, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000383ac38e 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026c07c0a 13. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x0000000026c0782d 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000026c0755f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x0000000026c052d4 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1766: DB::StorageDistributed::flushClusterNodesAllDataImpl(std::shared_ptr, DB::SettingsChanges const&, bool) @ 0x000000003839e496 6. ./build_docker/./src/Storages/StorageDistributed.cpp:1738: DB::StorageDistributed::flushClusterNodesAllData(std::shared_ptr, DB::SettingsChanges const&) @ 0x00000000383a0d34 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1389: DB::InterpreterSystemQuery::flushDistributed(DB::ASTSystemQuery&) @ 0x000000003380f8d1 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:776: DB::InterpreterSystemQuery::execute() @ 0x00000000337e1268 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:00:19.184680 [ 9260 ] {5f4a86af-d6c0-438d-a4df-e318c6c0443a} executeQuery: Code: 341. DB::Exception: Some replicas doesn't finish metadata alter: Timeout exceeded while waiting for replicas r2 to process entry log-0000000003. Probably some replicas are inactive. (UNFINISHED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33142) (comment: 00754_alter_modify_order_by_replicated_zookeeper_long.sql) (query 28, line 50) (in query: ALTER TABLE summing_r1 ADD COLUMN t UInt32 AFTER z, MODIFY ORDER BY (x, y, t * t) SETTINGS replication_alter_partitions_sync = 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type, std::type_identity::type>, String const&, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x0000000038bbca97 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7175: DB::StorageReplicatedMergeTree::waitForAllReplicasToProcessLogEntry(String const&, DB::ReplicatedMergeTreeLogEntryData const&, long, String const&) @ 0x0000000038a53e88 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7194: DB::StorageReplicatedMergeTree::waitForLogEntryToBeProcessedIfNecessary(DB::ReplicatedMergeTreeLogEntryData const&, std::shared_ptr, String const&) @ 0x00000000389f53e6 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6713: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a09626 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:00:19.200761 [ 9260 ] {} TCPHandler: Code: 341. DB::Exception: Some replicas doesn't finish metadata alter: Timeout exceeded while waiting for replicas r2 to process entry log-0000000003. Probably some replicas are inactive. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type, std::type_identity::type>, String const&, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x0000000038bbca97 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7175: DB::StorageReplicatedMergeTree::waitForAllReplicasToProcessLogEntry(String const&, DB::ReplicatedMergeTreeLogEntryData const&, long, String const&) @ 0x0000000038a53e88 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7194: DB::StorageReplicatedMergeTree::waitForLogEntryToBeProcessedIfNecessary(DB::ReplicatedMergeTreeLogEntryData const&, std::shared_ptr, String const&) @ 0x00000000389f53e6 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6713: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a09626 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:00:19.474160 [ 37802 ] {efb5b0ac-3c75-4e2e-8cb4-dbfbcac38ce4} test_3qcuynmr.dist.DistributedInsertQueue.default: File /var/lib/clickhouse/store/eae/eaeeef14-4712-4362-9d60-ac3b24ba202c/shard1_replica1/2.bin does not exist, likely due to current_batch.txt processing 2025.06.13 09:00:27.815283 [ 9261 ] {15f20279-456c-4ea0-9bce-a77f8e9dd079} executeQuery: Code: 481. DB::Exception: SQLite database file path '/etc/passwd' must be inside 'user_files' directory. (PATH_ACCESS_DENIED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45810) (comment: 02918_sqlite_path_check.sh) (query 1, line 1) (in query: Select * from sqlite('/etc/passwd', 'something');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008c167de 3. ./build_docker/./src/Databases/SQLite/SQLiteUtils.cpp:22: DB::processSQLiteError(String const&, bool) @ 0x000000002d09a05b 4. ./build_docker/./src/Databases/SQLite/SQLiteUtils.cpp:37: DB::validateSQLiteDatabasePath(String const&, String const&, bool, bool) @ 0x000000002d09c630 5. ./build_docker/./src/Databases/SQLite/SQLiteUtils.cpp:49: DB::openSQLiteDB(String const&, std::shared_ptr, bool) @ 0x000000002d09d1a5 6. ./build_docker/./src/TableFunctions/TableFunctionSQLite.cpp:91: DB::(anonymous namespace)::TableFunctionSQLite::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000266b316b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 09:00:27.825846 [ 9261 ] {} TCPHandler: Code: 481. DB::Exception: SQLite database file path '/etc/passwd' must be inside 'user_files' directory. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008c167de 3. ./build_docker/./src/Databases/SQLite/SQLiteUtils.cpp:22: DB::processSQLiteError(String const&, bool) @ 0x000000002d09a05b 4. ./build_docker/./src/Databases/SQLite/SQLiteUtils.cpp:37: DB::validateSQLiteDatabasePath(String const&, String const&, bool, bool) @ 0x000000002d09c630 5. ./build_docker/./src/Databases/SQLite/SQLiteUtils.cpp:49: DB::openSQLiteDB(String const&, std::shared_ptr, bool) @ 0x000000002d09d1a5 6. ./build_docker/./src/TableFunctions/TableFunctionSQLite.cpp:91: DB::(anonymous namespace)::TableFunctionSQLite::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000266b316b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 09:00:28.690578 [ 15837 ] {f28c3451-3dcd-4700-9e7a-1fe8ba41307e} executeQuery: Code: 481. DB::Exception: SQLite database file path '../../../../etc/passwd' must be inside 'user_files' directory. (PATH_ACCESS_DENIED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45834) (comment: 02918_sqlite_path_check.sh) (query 1, line 1) (in query: Select * from sqlite('../../../../etc/passwd', 'something');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008c167de 3. ./build_docker/./src/Databases/SQLite/SQLiteUtils.cpp:22: DB::processSQLiteError(String const&, bool) @ 0x000000002d09a05b 4. ./build_docker/./src/Databases/SQLite/SQLiteUtils.cpp:37: DB::validateSQLiteDatabasePath(String const&, String const&, bool, bool) @ 0x000000002d09c630 5. ./build_docker/./src/Databases/SQLite/SQLiteUtils.cpp:49: DB::openSQLiteDB(String const&, std::shared_ptr, bool) @ 0x000000002d09d1a5 6. ./build_docker/./src/TableFunctions/TableFunctionSQLite.cpp:91: DB::(anonymous namespace)::TableFunctionSQLite::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000266b316b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 09:00:28.705283 [ 15837 ] {} TCPHandler: Code: 481. DB::Exception: SQLite database file path '../../../../etc/passwd' must be inside 'user_files' directory. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008c167de 3. ./build_docker/./src/Databases/SQLite/SQLiteUtils.cpp:22: DB::processSQLiteError(String const&, bool) @ 0x000000002d09a05b 4. ./build_docker/./src/Databases/SQLite/SQLiteUtils.cpp:37: DB::validateSQLiteDatabasePath(String const&, String const&, bool, bool) @ 0x000000002d09c630 5. ./build_docker/./src/Databases/SQLite/SQLiteUtils.cpp:49: DB::openSQLiteDB(String const&, std::shared_ptr, bool) @ 0x000000002d09d1a5 6. ./build_docker/./src/TableFunctions/TableFunctionSQLite.cpp:91: DB::(anonymous namespace)::TableFunctionSQLite::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000266b316b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030330a38 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 09:00:28.922445 [ 24861 ] {93565bf3-176b-4aa7-8cb4-3addae5db994} executeQuery: Code: 53. DB::Exception: Cannot convert string '1.0' to type UInt8: In scope SELECT 1 = '1.0'. (TYPE_MISMATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45796) (comment: 01311_comparison_with_constant_string.sql) (query 12, line 13) (in query: -- it should work but it doesn't. SELECT 1 = '1.0';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000003368310c 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000003367a53e 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dee1cc7 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000de985f4 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 2025.06.13 09:00:28.927504 [ 24861 ] {} TCPHandler: Code: 53. DB::Exception: Cannot convert string '1.0' to type UInt8: In scope SELECT 1 = '1.0'. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000003368310c 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000003367a53e 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dee1cc7 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000de985f4 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 2025.06.13 09:00:30.431972 [ 24861 ] {9c5b5b2f-d287-478c-9c0c-402e1c1ac43c} executeQuery: Code: 32. DB::Exception: Attempt to read after eof: while converting '' to UInt8: In scope SELECT 0 = ''. (ATTEMPT_TO_READ_AFTER_EOF) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45796) (comment: 01311_comparison_with_constant_string.sql) (query 28, line 33) (in query: SELECT 0 = '';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/IO/VarInt.cpp:13: DB::throwReadAfterEOF() @ 0x000000001f8f6d6c 5. ./src/IO/ReadHelpers.h:537: DB::SerializationNumber::deserializeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x000000002f639a8a 6. DB::SimpleTextSerialization::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000008dcf546 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:578: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000033680634 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000003367a53e 9. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dee1cc7 10. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000de985f4 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 09:00:30.437974 [ 24861 ] {} TCPHandler: Code: 32. DB::Exception: Attempt to read after eof: while converting '' to UInt8: In scope SELECT 0 = ''. (ATTEMPT_TO_READ_AFTER_EOF), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/IO/VarInt.cpp:13: DB::throwReadAfterEOF() @ 0x000000001f8f6d6c 5. ./src/IO/ReadHelpers.h:537: DB::SerializationNumber::deserializeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x000000002f639a8a 6. DB::SimpleTextSerialization::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000008dcf546 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:578: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000033680634 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000003367a53e 9. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dee1cc7 10. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000de985f4 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 2025.06.13 09:00:34.260753 [ 15838 ] {7e3ab132-92ce-439c-8c8e-da8f9c22996f} executeQuery: Code: 210. DB::Exception: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:36260): While executing ParallelFormattingOutputFormat. (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:36260) (comment: 03280_cancelation_http_when_outputformat.sh) (in query: SELECT toDate('2020-12-12') as datetime, 'test-pipeline' as pipeline, 'clickhouse-test-host-001.clickhouse.com' as host, 'clickhouse' as home, 'clickhouse' as detail, number as row_number FROM numbers(1000000) SETTINGS max_block_size=65505 FORMAT JSON), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./src/Server/HTTP/HTTPServerResponse.h:197: DB::HTTPWriteBuffer::nextImplChunked() @ 0x000000003ae37194 5. ./src/Server/HTTP/HTTPServerResponse.h:166: DB::WriteBufferFromHTTPServerResponse::nextImpl() @ 0x000000003ae3037f 6. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 7. ./src/IO/WriteBuffer.h:85: DB::ZstdDeflatingWriteBuffer::flush(ZSTD_EndDirective) @ 0x000000001ff7c665 8. ./build_docker/./src/IO/ZstdDeflatingWriteBuffer.cpp:104: DB::ZstdDeflatingWriteBuffer::nextImpl() @ 0x000000001ff7ce2f 9. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 10. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x000000001f8f7c9a 11. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:157: DB::ParallelFormattingOutputFormat::collectorThreadFunction(std::shared_ptr const&) @ 0x000000003b5f4506 12. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:107: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params)::'lambda'()&&)::'lambda'()::operator()() @ 0x000000003aeb92db 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params)::'lambda'()&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb909f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:00:34.401932 [ 15838 ] {7e3ab132-92ce-439c-8c8e-da8f9c22996f} DynamicQueryHandler: Code: 210. DB::Exception: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:36260): While executing ParallelFormattingOutputFormat. (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./src/Server/HTTP/HTTPServerResponse.h:197: DB::HTTPWriteBuffer::nextImplChunked() @ 0x000000003ae37194 5. ./src/Server/HTTP/HTTPServerResponse.h:166: DB::WriteBufferFromHTTPServerResponse::nextImpl() @ 0x000000003ae3037f 6. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 7. ./src/IO/WriteBuffer.h:85: DB::ZstdDeflatingWriteBuffer::flush(ZSTD_EndDirective) @ 0x000000001ff7c665 8. ./build_docker/./src/IO/ZstdDeflatingWriteBuffer.cpp:104: DB::ZstdDeflatingWriteBuffer::nextImpl() @ 0x000000001ff7ce2f 9. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 10. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x000000001f8f7c9a 11. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:157: DB::ParallelFormattingOutputFormat::collectorThreadFunction(std::shared_ptr const&) @ 0x000000003b5f4506 12. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:107: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params)::'lambda'()&&)::'lambda'()::operator()() @ 0x000000003aeb92db 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params)::'lambda'()&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003aeb909f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params)::'lambda'()&&) @ 0x000000003aeafbf9 5. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:105: DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params) @ 0x000000003aeaebd9 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::ParallelFormattingOutputFormat* std::construct_at[abi:ne190107](DB::ParallelFormattingOutputFormat*, DB::ParallelFormattingOutputFormat::Params&) @ 0x000000003aead51d 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003ae90a9a 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1847: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000033743438 9. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:00:34.496853 [ 15838 ] {7e3ab132-92ce-439c-8c8e-da8f9c22996f} bool DB::WriteBufferFromHTTPServerResponse::cancelWithException(HTTPServerRequest &, int, const std::string &, WriteBuffer *): Failed to send exception to the response write buffer.: Code: 236. DB::Exception: Write buffer has been canceled. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:248: DB::WriteBufferFromHTTPServerResponse::cancelWithException(DB::HTTPServerRequest&, int, String const&, DB::WriteBuffer*) @ 0x000000003ae3305e 5. ./build_docker/./src/Server/HTTPHandler.cpp:664: DB::HTTPHandler::trySendExceptionToClient(int, String const&, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x000000003abd125b 6. ./build_docker/./src/Server/HTTPHandler.cpp:771: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd88f8 7. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:00:38.856065 [ 2136 ] {f37ef84d-f5f5-48be-a218-0e0f1c4d8996} executeQuery: Code: 69. DB::Exception: A call to function range would produce 12 array elements, which is greater than the allowed maximum of 10: while executing 'FUNCTION range(modulo(__table1.number, 3_UInt8) :: 0) -> range(modulo(__table1.number, 3_UInt8)) Array(UInt8) : 1'. (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33980) (comment: 01944_range_max_elements.sql) (query 4, line 4) (in query: SELECT range(number % 3) FROM numbers(12);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. COW::immutable_ptr DB::FunctionRange::executeInternal(DB::IColumn const*) const @ 0x000000001f4794f4 5. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f46e4eb 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 12. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 09:00:38.869465 [ 2136 ] {} TCPHandler: Code: 69. DB::Exception: A call to function range would produce 12 array elements, which is greater than the allowed maximum of 10: while executing 'FUNCTION range(modulo(__table1.number, 3_UInt8) :: 0) -> range(modulo(__table1.number, 3_UInt8)) Array(UInt8) : 1'. (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. COW::immutable_ptr DB::FunctionRange::executeInternal(DB::IColumn const*) const @ 0x000000001f4794f4 5. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f46e4eb 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 12. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:00:42.635301 [ 2085 ] {68e851b8-37ac-4bff-82a3-72701e671702} executeQuery: Code: 378. DB::Exception: Data type Bool cannot have arguments: In scope SELECT CAST('0', 'Bool(Upyachka)'). (DATA_TYPE_CANNOT_HAVE_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34102) (comment: 02689_meaningless_data_types.sql) (query 1, line 1) (in query: SELECT 0::Bool(Upyachka);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:213: std::pair, std::unique_ptr>> std::__function::__policy_invoker, std::unique_ptr>> (std::shared_ptr const&)>::__call_impl[abi:ne190107], std::unique_ptr>> ()>, DB::IFactoryWithAliases (std::shared_ptr const&)>>::Case)::$_0, std::pair, std::unique_ptr>> (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x000000002f2961fe 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f295b35 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f297d11 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:73: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x000000002f296bd0 8. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:35: DB::DataTypeFactory::get(String const&) const @ 0x000000002f291f77 9. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002c194d32 10. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7eb0 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 2025.06.13 09:00:42.641897 [ 2085 ] {} TCPHandler: Code: 378. DB::Exception: Data type Bool cannot have arguments: In scope SELECT CAST('0', 'Bool(Upyachka)'). (DATA_TYPE_CANNOT_HAVE_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:213: std::pair, std::unique_ptr>> std::__function::__policy_invoker, std::unique_ptr>> (std::shared_ptr const&)>::__call_impl[abi:ne190107], std::unique_ptr>> ()>, DB::IFactoryWithAliases (std::shared_ptr const&)>>::Case)::$_0, std::pair, std::unique_ptr>> (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x000000002f2961fe 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f295b35 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f297d11 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:73: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x000000002f296bd0 8. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:35: DB::DataTypeFactory::get(String const&) const @ 0x000000002f291f77 9. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002c194d32 10. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7eb0 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 2025.06.13 09:00:42.672418 [ 2085 ] {cc8ef261-af23-4560-80cc-58fa6390e99e} executeQuery: Code: 378. DB::Exception: Data type Ring cannot have arguments: In scope SELECT CAST('[(1, 2), (3, 4)]', 'Ring(Upyachka)'). (DATA_TYPE_CANNOT_HAVE_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34102) (comment: 02689_meaningless_data_types.sql) (query 2, line 2) (in query: SELECT [(1, 2), (3, 4)]::Ring(Upyachka);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:213: std::pair, std::unique_ptr>> std::__function::__policy_invoker, std::unique_ptr>> (std::shared_ptr const&)>::__call_impl[abi:ne190107], std::unique_ptr>> ()>, DB::IFactoryWithAliases (std::shared_ptr const&)>>::Case)::$_0, std::pair, std::unique_ptr>> (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x000000002f2961fe 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f295b35 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f297d11 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:73: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x000000002f296bd0 8. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:35: DB::DataTypeFactory::get(String const&) const @ 0x000000002f291f77 9. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002c194d32 10. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7eb0 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 2025.06.13 09:00:42.680958 [ 2085 ] {} TCPHandler: Code: 378. DB::Exception: Data type Ring cannot have arguments: In scope SELECT CAST('[(1, 2), (3, 4)]', 'Ring(Upyachka)'). (DATA_TYPE_CANNOT_HAVE_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:213: std::pair, std::unique_ptr>> std::__function::__policy_invoker, std::unique_ptr>> (std::shared_ptr const&)>::__call_impl[abi:ne190107], std::unique_ptr>> ()>, DB::IFactoryWithAliases (std::shared_ptr const&)>>::Case)::$_0, std::pair, std::unique_ptr>> (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x000000002f2961fe 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f295b35 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f297d11 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:73: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x000000002f296bd0 8. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:35: DB::DataTypeFactory::get(String const&) const @ 0x000000002f291f77 9. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002c194d32 10. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7eb0 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 2025.06.13 09:00:42.963287 [ 2085 ] {1096acdb-7f77-46dc-9bbf-310925893ff6} executeQuery: Code: 378. DB::Exception: Data type IPv4 cannot have arguments: In scope SELECT CAST('1.1.1.1', 'IPv4(\'Hello, world!\')'). (DATA_TYPE_CANNOT_HAVE_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34102) (comment: 02689_meaningless_data_types.sql) (query 3, line 3) (in query: SELECT '1.1.1.1'::IPv4('Hello, world!');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:192: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:ne190107] ()>, DB::IFactoryWithAliases (std::shared_ptr const&)>>::Case)::$_0, std::shared_ptr (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x000000002f2955c5 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f297d11 6. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:73: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x000000002f296bd0 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:35: DB::DataTypeFactory::get(String const&) const @ 0x000000002f291f77 8. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002c194d32 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7eb0 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 09:00:42.970325 [ 2085 ] {} TCPHandler: Code: 378. DB::Exception: Data type IPv4 cannot have arguments: In scope SELECT CAST('1.1.1.1', 'IPv4(\'Hello, world!\')'). (DATA_TYPE_CANNOT_HAVE_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:192: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:ne190107] ()>, DB::IFactoryWithAliases (std::shared_ptr const&)>>::Case)::$_0, std::shared_ptr (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x000000002f2955c5 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f297d11 6. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:73: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x000000002f296bd0 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:35: DB::DataTypeFactory::get(String const&) const @ 0x000000002f291f77 8. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002c194d32 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7eb0 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 09:00:47.433661 [ 2137 ] {1befa178-269b-49d4-8137-dfcc40315c59} executeQuery: Code: 207. DB::Exception: Cannot select subcolumn for identifier 't' while joining using column 't.t'. (AMBIGUOUS_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58690) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (query 34, line 48) (in query: SELECT t FROM na FULL JOIN nb USING (t.t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x0000000031049c8d 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:926: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x000000003103c85e 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:965: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000310396b7 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003103680c 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000031044302 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b991 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 09:00:47.441268 [ 2137 ] {} TCPHandler: Code: 207. DB::Exception: Cannot select subcolumn for identifier 't' while joining using column 't.t'. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x0000000031049c8d 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:926: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x000000003103c85e 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:965: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000310396b7 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003103680c 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000031044302 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b991 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 09:00:48.099567 [ 2137 ] {c7cef84d-8f95-4360-83dc-385205b22fdc} executeQuery: Code: 207. DB::Exception: Cannot select subcolumn for identifier 'na.t' while joining using column 't.t'. (AMBIGUOUS_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58690) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (query 37, line 51) (in query: SELECT na.t FROM na FULL JOIN nb USING (t.t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x0000000031049c8d 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:926: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x000000003103c85e 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1027: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003103a131 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003103680c 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000031044302 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b991 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 09:00:48.105975 [ 2137 ] {} TCPHandler: Code: 207. DB::Exception: Cannot select subcolumn for identifier 'na.t' while joining using column 't.t'. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x0000000031049c8d 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:926: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x000000003103c85e 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1027: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003103a131 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003103680c 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000031044302 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b991 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 09:00:48.587834 [ 2137 ] {2a4f4ec5-5430-4fac-bb0c-1df95d1579dd} executeQuery: Code: 207. DB::Exception: Cannot select subcolumn for identifier 'nb.t' while joining using column 't.t'. (AMBIGUOUS_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58690) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (query 39, line 53) (in query: SELECT nb.t FROM na FULL JOIN nb USING (t.t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x0000000031049c8d 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:926: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x000000003103c85e 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1052: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003103a112 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003103680c 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000031044302 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b991 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 09:00:48.594036 [ 2137 ] {} TCPHandler: Code: 207. DB::Exception: Cannot select subcolumn for identifier 'nb.t' while joining using column 't.t'. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x0000000031049c8d 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:926: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x000000003103c85e 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1052: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003103a112 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003103680c 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000031044302 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b991 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 09:00:49.643899 [ 9261 ] {abea5efb-dcaa-47fc-b73d-f85738e0014d} executeQuery: Code: 36. DB::Exception: Existing column a is used in the expression that was added to the sorting key. You can add expressions that use only the newly added columns. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58880) (comment: 00754_alter_modify_order_by.sql) (query 5, line 6) (in query: ALTER TABLE no_order MODIFY ORDER BY (a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:781: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000039778b7a 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3860: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003981e60c 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:00:49.652048 [ 9261 ] {} TCPHandler: Code: 36. DB::Exception: Existing column a is used in the expression that was added to the sorting key. You can add expressions that use only the newly added columns. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:781: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000039778b7a 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3860: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003981e60c 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:00:50.033580 [ 9261 ] {2f614d8a-d0fc-4595-949b-d80ee0b8017c} executeQuery: Code: 36. DB::Exception: ALTER MODIFY ORDER BY is not supported for default-partitioned tables created with the old syntax. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58880) (comment: 00754_alter_modify_order_by.sql) (query 10, line 13) (in query: ALTER TABLE old_style ADD COLUMN y UInt32, MODIFY ORDER BY (x, y);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3698: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003982285d 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:00:50.042184 [ 9261 ] {} TCPHandler: Code: 36. DB::Exception: ALTER MODIFY ORDER BY is not supported for default-partitioned tables created with the old syntax. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3698: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003982285d 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:00:50.364135 [ 9261 ] {1d410b4c-4096-4a1c-bdd4-ac71e4a58876} executeQuery: Code: 36. DB::Exception: Existing column val is used in the expression that was added to the sorting key. You can add expressions that use only the newly added columns. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58880) (comment: 00754_alter_modify_order_by.sql) (query 14, line 19) (in query: /* Can't add an expression with existing column to ORDER BY. */ ALTER TABLE summing MODIFY ORDER BY (x, y, -val);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:781: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000039778b7a 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3860: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003981e60c 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:00:50.370900 [ 9261 ] {} TCPHandler: Code: 36. DB::Exception: Existing column val is used in the expression that was added to the sorting key. You can add expressions that use only the newly added columns. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:781: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000039778b7a 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3860: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003981e60c 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:00:50.498565 [ 9261 ] {af40c4d5-42d3-4f34-875b-d3618d351483} executeQuery: Code: 36. DB::Exception: Newly added column z has a default expression, so adding expressions that use it to the sorting key is forbidden. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58880) (comment: 00754_alter_modify_order_by.sql) (query 15, line 22) (in query: /* Can't add an expression with existing column to ORDER BY. */ ALTER TABLE summing ADD COLUMN z UInt32 DEFAULT x + 1, MODIFY ORDER BY (x, y, -z);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:787: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000039779296 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3860: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003981e60c 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:00:50.506190 [ 9261 ] {} TCPHandler: Code: 36. DB::Exception: Newly added column z has a default expression, so adding expressions that use it to the sorting key is forbidden. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:787: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000039779296 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3860: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003981e60c 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:00:50.585108 [ 9261 ] {d6fd29af-02be-4a7b-bd1d-9e446b34f35d} executeQuery: Code: 47. DB::Exception: Missing columns: 'nonexistent' while processing: 'x, y, nonexistent', required columns: 'x' 'y' 'nonexistent', available columns: 'val' 'y' 'x'. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58880) (comment: 00754_alter_modify_order_by.sql) (query 16, line 25) (in query: /* Can't add nonexistent column to ORDER BY. */ ALTER TABLE summing MODIFY ORDER BY (x, y, nonexistent);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1303: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x0000000033504085 4. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1561: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003352681b 5. ./build_docker/./src/Storages/KeyDescription.cpp:163: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000038292ce9 6. ./build_docker/./src/Storages/KeyDescription.cpp:78: DB::KeyDescription::recalculateWithNewAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x00000000382902c7 7. ./build_docker/./src/Storages/AlterCommands.cpp:666: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000038174aef 8. ./build_docker/./src/Storages/AlterCommands.cpp:1263: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000003818ab70 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003981884d 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 09:00:50.592667 [ 9261 ] {} TCPHandler: Code: 47. DB::Exception: Missing columns: 'nonexistent' while processing: 'x, y, nonexistent', required columns: 'x' 'y' 'nonexistent', available columns: 'val' 'y' 'x'. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1303: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x0000000033504085 4. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1561: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003352681b 5. ./build_docker/./src/Storages/KeyDescription.cpp:163: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000038292ce9 6. ./build_docker/./src/Storages/KeyDescription.cpp:78: DB::KeyDescription::recalculateWithNewAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x00000000382902c7 7. ./build_docker/./src/Storages/AlterCommands.cpp:666: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000038174aef 8. ./build_docker/./src/Storages/AlterCommands.cpp:1263: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000003818ab70 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003981884d 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 09:00:50.676045 [ 9261 ] {f5add6f6-0d16-469b-b0d5-fe89805303c8} executeQuery: Code: 36. DB::Exception: Primary key must be a prefix of the sorting key, but its length: 2 is greater than the sorting key length: 1. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58880) (comment: 00754_alter_modify_order_by.sql) (query 17, line 28) (in query: /* Can't modyfy ORDER BY so that it is no longer a prefix of the PRIMARY KEY. */ ALTER TABLE summing MODIFY ORDER BY x;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b1188ad 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:720: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x000000003977579c 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3860: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003981e60c 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:00:50.683094 [ 9261 ] {} TCPHandler: Code: 36. DB::Exception: Primary key must be a prefix of the sorting key, but its length: 2 is greater than the sorting key length: 1. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b1188ad 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:720: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x000000003977579c 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3860: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003981e60c 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:00:51.972646 [ 2137 ] {3f35ad11-e06e-45e0-9431-8030a25906a6} executeQuery: Code: 207. DB::Exception: Cannot select subcolumn for identifier 't.t' while joining using column 't'. (AMBIGUOUS_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58690) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (query 58, line 79) (in query: SELECT t.t FROM (SELECT (1, 's') :: Tuple(t Int32, s String) as t ) as na FULL JOIN (SELECT (1, 's') :: Tuple(t UInt32, s String) as t ) as nb USING (t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x0000000031049c8d 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:926: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x000000003103c85e 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:965: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000310396b7 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003103680c 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000031044302 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b991 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 09:00:51.979546 [ 2137 ] {} TCPHandler: Code: 207. DB::Exception: Cannot select subcolumn for identifier 't.t' while joining using column 't'. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x0000000031049c8d 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:926: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x000000003103c85e 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:965: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000310396b7 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003103680c 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000031044302 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b991 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 09:00:52.222095 [ 2137 ] {d146f8b0-7638-4bb5-8ebd-6eebd2a1ba51} executeQuery: Code: 1. DB::Exception: JOIN FULL OUTER JOIN ... USING (t.t) using identifier 't.t' must be resolved into column node from left table expression. In scope SELECT * FROM (SELECT CAST('(1, \'s\')', 'Tuple(t Int32, s String)') AS t) AS na FULL OUTER JOIN (SELECT CAST('(1, \'s\')', 'Tuple(t UInt32, s String)') AS t) AS nb USING (t.t). (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58690) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (query 59, line 80) (in query: SELECT * FROM (SELECT (1, 's') :: Tuple(t Int32, s String) as t ) as na FULL JOIN (SELECT (1, 's') :: Tuple(t UInt32, s String) as t ) as nb USING (t.t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000303de2b7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5264: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303d42b2 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f5a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 09:00:52.229197 [ 2137 ] {} TCPHandler: Code: 1. DB::Exception: JOIN FULL OUTER JOIN ... USING (t.t) using identifier 't.t' must be resolved into column node from left table expression. In scope SELECT * FROM (SELECT CAST('(1, \'s\')', 'Tuple(t Int32, s String)') AS t) AS na FULL OUTER JOIN (SELECT CAST('(1, \'s\')', 'Tuple(t UInt32, s String)') AS t) AS nb USING (t.t). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000303de2b7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5264: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303d42b2 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f5a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 09:00:52.337482 [ 2137 ] {71c84a38-0e1b-4e29-9de0-6ea4cf93a140} executeQuery: Code: 1. DB::Exception: JOIN FULL OUTER JOIN ... USING (t.t) using identifier 't.t' must be resolved into column node from left table expression. In scope SELECT t AS e, toTypeName(e) FROM (SELECT CAST('((((1, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String)') AS t) AS ttta FULL OUTER JOIN (SELECT CAST('((((2, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String)') AS t) AS tttb USING (t.t). (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58690) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (query 60, line 82) (in query: SELECT t as e, toTypeName(e) FROM ( SELECT ((((1, 's'), 's'), 's'), 's') :: Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String) as t ) ttta FULL JOIN ( SELECT ((((2, 's'), 's'), 's'), 's') :: Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String) as t ) tttb USING (t.t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000303de2b7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5264: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303d42b2 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f5a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 09:00:52.346944 [ 2137 ] {} TCPHandler: Code: 1. DB::Exception: JOIN FULL OUTER JOIN ... USING (t.t) using identifier 't.t' must be resolved into column node from left table expression. In scope SELECT t AS e, toTypeName(e) FROM (SELECT CAST('((((1, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String)') AS t) AS ttta FULL OUTER JOIN (SELECT CAST('((((2, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String)') AS t) AS tttb USING (t.t). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000303de2b7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5264: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303d42b2 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f5a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 09:00:52.441661 [ 2137 ] {5016e0c5-a52c-4dff-a2fa-27853b28a7a4} executeQuery: Code: 1. DB::Exception: JOIN FULL OUTER JOIN ... USING (t.t) using identifier 't.t' must be resolved into column node from left table expression. In scope SELECT t.t AS e, toTypeName(e) FROM (SELECT CAST('((((1, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String)') AS t) AS ttta FULL OUTER JOIN (SELECT CAST('((((2, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String)') AS t) AS tttb USING (t.t). (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58690) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (query 61, line 88) (in query: SELECT t.t as e, toTypeName(e) FROM ( SELECT ((((1, 's'), 's'), 's'), 's') :: Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String) as t ) ttta FULL JOIN ( SELECT ((((2, 's'), 's'), 's'), 's') :: Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String) as t ) tttb USING (t.t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000303de2b7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5264: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303d42b2 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f5a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 09:00:52.448771 [ 2137 ] {} TCPHandler: Code: 1. DB::Exception: JOIN FULL OUTER JOIN ... USING (t.t) using identifier 't.t' must be resolved into column node from left table expression. In scope SELECT t.t AS e, toTypeName(e) FROM (SELECT CAST('((((1, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String)') AS t) AS ttta FULL OUTER JOIN (SELECT CAST('((((2, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String)') AS t) AS tttb USING (t.t). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000303de2b7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5264: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303d42b2 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f5a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 09:00:52.514911 [ 2137 ] {98aaad64-e711-4a12-b6d0-7d4f1d674789} executeQuery: Code: 1. DB::Exception: JOIN FULL OUTER JOIN ... USING (t.t) using identifier 't.t' must be resolved into column node from left table expression. In scope SELECT t.t.t AS e, toTypeName(e) FROM (SELECT CAST('((((1, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String)') AS t) AS ttta FULL OUTER JOIN (SELECT CAST('((((2, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String)') AS t) AS tttb USING (t.t). (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58690) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (query 62, line 94) (in query: SELECT t.t.t as e, toTypeName(e) FROM ( SELECT ((((1, 's'), 's'), 's'), 's') :: Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String) as t ) ttta FULL JOIN ( SELECT ((((2, 's'), 's'), 's'), 's') :: Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String) as t ) tttb USING (t.t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000303de2b7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5264: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303d42b2 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f5a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 09:00:52.523415 [ 2137 ] {} TCPHandler: Code: 1. DB::Exception: JOIN FULL OUTER JOIN ... USING (t.t) using identifier 't.t' must be resolved into column node from left table expression. In scope SELECT t.t.t AS e, toTypeName(e) FROM (SELECT CAST('((((1, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String)') AS t) AS ttta FULL OUTER JOIN (SELECT CAST('((((2, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String)') AS t) AS tttb USING (t.t). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000303de2b7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5264: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303d42b2 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f5a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 09:00:52.892586 [ 2137 ] {bd350537-8c62-4f54-8e46-9ab696fc7a7d} executeQuery: Code: 207. DB::Exception: Cannot select subcolumn for identifier 't.t' while joining using column 't'. (AMBIGUOUS_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58690) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (query 64, line 106) (in query: SELECT t.t as e, toTypeName(e) FROM ( SELECT ((((1, 's'), 's'), 's'), 's') :: Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String) as t ) ttta FULL JOIN ( SELECT ((((2, 's'), 's'), 's'), 's') :: Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String) as t ) tttb USING (t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x0000000031049c8d 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:926: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x000000003103c85e 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:965: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000310396b7 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003103680c 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000031044302 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b991 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 09:00:52.899833 [ 2137 ] {} TCPHandler: Code: 207. DB::Exception: Cannot select subcolumn for identifier 't.t' while joining using column 't'. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x0000000031049c8d 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:926: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x000000003103c85e 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:965: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000310396b7 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003103680c 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000031044302 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b991 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 09:00:55.315902 [ 9234 ] {98cfc985-328b-40a9-a126-0bb56dd5c8ed} executeQuery: Code: 48. DB::Exception: TRUNCATE DATABASE is not implemented for replicated databases. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41658) (comment: 03362_create_table_after_truncate_replicated_database.sql) (query 5, line 12) (in query: TRUNCATE DATABASE test_6tp9cgmm), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:402: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032978553 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032969430 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965ed2 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:00:55.322459 [ 9234 ] {} TCPHandler: Code: 48. DB::Exception: TRUNCATE DATABASE is not implemented for replicated databases. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:402: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032978553 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032969430 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965ed2 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:00:55.825632 [ 24860 ] {aac190d8-6f84-4dc7-8a8e-0c030d2ccc63} executeQuery: Code: 36. DB::Exception: Column `some_column` doesn't have DEFAULT, cannot remove it. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41682) (comment: 01493_alter_remove_no_property_zookeeper_long.sql) (query 4, line 14) (in query: -- just nothing happened ALTER TABLE no_prop_table MODIFY COLUMN some_column REMOVE DEFAULT;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1551: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819b4a7 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:00:55.832017 [ 24860 ] {} TCPHandler: Code: 36. DB::Exception: Column `some_column` doesn't have DEFAULT, cannot remove it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1551: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819b4a7 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:00:55.994117 [ 24860 ] {387f4c3c-525b-4cd8-85e5-0f7c4c54f00b} executeQuery: Code: 36. DB::Exception: Column `some_column` doesn't have MATERIALIZED, cannot remove it. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41682) (comment: 01493_alter_remove_no_property_zookeeper_long.sql) (query 5, line 16) (in query: ALTER TABLE no_prop_table MODIFY COLUMN some_column REMOVE MATERIALIZED;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1563: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819b200 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:00:55.999862 [ 24860 ] {} TCPHandler: Code: 36. DB::Exception: Column `some_column` doesn't have MATERIALIZED, cannot remove it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1563: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819b200 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:00:56.151375 [ 24860 ] {d6ddd4df-d219-460d-8885-480e869b6224} executeQuery: Code: 36. DB::Exception: Column `some_column` doesn't have ALIAS, cannot remove it. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41682) (comment: 01493_alter_remove_no_property_zookeeper_long.sql) (query 6, line 17) (in query: ALTER TABLE no_prop_table MODIFY COLUMN some_column REMOVE ALIAS;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1557: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819b887 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:00:56.157787 [ 24860 ] {} TCPHandler: Code: 36. DB::Exception: Column `some_column` doesn't have ALIAS, cannot remove it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1557: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819b887 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:00:56.310272 [ 24860 ] {986d7e4f-3a47-4fa7-9ba4-251b95c15a16} executeQuery: Code: 36. DB::Exception: Column `some_column` doesn't have CODEC, cannot remove it. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41682) (comment: 01493_alter_remove_no_property_zookeeper_long.sql) (query 7, line 18) (in query: ALTER TABLE no_prop_table MODIFY COLUMN some_column REMOVE CODEC;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1575: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819c91a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:00:56.317030 [ 24860 ] {} TCPHandler: Code: 36. DB::Exception: Column `some_column` doesn't have CODEC, cannot remove it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1575: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819c91a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:00:56.470972 [ 24860 ] {dad77319-f3ba-4b83-a461-226c00d21527} executeQuery: Code: 36. DB::Exception: Column `some_column` doesn't have COMMENT, cannot remove it. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41682) (comment: 01493_alter_remove_no_property_zookeeper_long.sql) (query 8, line 19) (in query: ALTER TABLE no_prop_table MODIFY COLUMN some_column REMOVE COMMENT;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1580: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819cbbe 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:00:56.477357 [ 24860 ] {} TCPHandler: Code: 36. DB::Exception: Column `some_column` doesn't have COMMENT, cannot remove it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1580: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819cbbe 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:00:56.633330 [ 24860 ] {a42ed1fa-e2ec-4f7d-bb33-e93d03f1d64b} executeQuery: Code: 36. DB::Exception: Column `some_column` doesn't have TTL, cannot remove it. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41682) (comment: 01493_alter_remove_no_property_zookeeper_long.sql) (query 9, line 20) (in query: ALTER TABLE no_prop_table MODIFY COLUMN some_column REMOVE TTL;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1570: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819c671 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:00:56.640174 [ 24860 ] {} TCPHandler: Code: 36. DB::Exception: Column `some_column` doesn't have TTL, cannot remove it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1570: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819c671 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:00:56.794456 [ 24860 ] {e675158e-be6f-4eed-9a5e-9837a3159de5} executeQuery: Code: 36. DB::Exception: Table doesn't have any table TTL expression, cannot remove. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41682) (comment: 01493_alter_remove_no_property_zookeeper_long.sql) (query 10, line 22) (in query: ALTER TABLE no_prop_table REMOVE TTL;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/AlterCommands.cpp:1709: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000038198ded 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:00:56.800175 [ 24860 ] {} TCPHandler: Code: 36. DB::Exception: Table doesn't have any table TTL expression, cannot remove. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/AlterCommands.cpp:1709: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000038198ded 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:00:57.342091 [ 24860 ] {7f24b3ce-26c1-4ed8-951d-9ce6cf3385de} executeQuery: Code: 36. DB::Exception: Column `some_column` doesn't have DEFAULT, cannot remove it. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41682) (comment: 01493_alter_remove_no_property_zookeeper_long.sql) (query 16, line 39) (in query: ALTER TABLE r_no_prop_table MODIFY COLUMN some_column REMOVE DEFAULT;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1551: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819b4a7 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:00:57.350220 [ 24860 ] {} TCPHandler: Code: 36. DB::Exception: Column `some_column` doesn't have DEFAULT, cannot remove it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1551: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819b4a7 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:00:57.382303 [ 24860 ] {50232b47-d660-445a-b1ea-8e8870aea485} executeQuery: Code: 36. DB::Exception: Column `some_column` doesn't have MATERIALIZED, cannot remove it. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41682) (comment: 01493_alter_remove_no_property_zookeeper_long.sql) (query 17, line 40) (in query: ALTER TABLE r_no_prop_table MODIFY COLUMN some_column REMOVE MATERIALIZED;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1563: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819b200 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:00:57.388967 [ 24860 ] {} TCPHandler: Code: 36. DB::Exception: Column `some_column` doesn't have MATERIALIZED, cannot remove it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1563: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819b200 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:00:57.420371 [ 24860 ] {600253bc-07f0-41d9-b2f8-22f771e4079f} executeQuery: Code: 36. DB::Exception: Column `some_column` doesn't have ALIAS, cannot remove it. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41682) (comment: 01493_alter_remove_no_property_zookeeper_long.sql) (query 18, line 41) (in query: ALTER TABLE r_no_prop_table MODIFY COLUMN some_column REMOVE ALIAS;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1557: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819b887 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:00:57.427289 [ 24860 ] {} TCPHandler: Code: 36. DB::Exception: Column `some_column` doesn't have ALIAS, cannot remove it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1557: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819b887 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:00:57.455855 [ 24860 ] {64724a84-6e84-4f28-b9dc-6b47d50de1ff} executeQuery: Code: 36. DB::Exception: Column `some_column` doesn't have CODEC, cannot remove it. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41682) (comment: 01493_alter_remove_no_property_zookeeper_long.sql) (query 19, line 42) (in query: ALTER TABLE r_no_prop_table MODIFY COLUMN some_column REMOVE CODEC;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1575: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819c91a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:00:57.462531 [ 24860 ] {} TCPHandler: Code: 36. DB::Exception: Column `some_column` doesn't have CODEC, cannot remove it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1575: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819c91a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:00:57.490274 [ 24860 ] {c669ac36-2103-4f53-a6ea-92af9d87e009} executeQuery: Code: 36. DB::Exception: Column `some_column` doesn't have COMMENT, cannot remove it. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41682) (comment: 01493_alter_remove_no_property_zookeeper_long.sql) (query 20, line 43) (in query: ALTER TABLE r_no_prop_table MODIFY COLUMN some_column REMOVE COMMENT;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1580: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819cbbe 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:00:57.496763 [ 24860 ] {} TCPHandler: Code: 36. DB::Exception: Column `some_column` doesn't have COMMENT, cannot remove it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1580: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819cbbe 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:00:57.524849 [ 24860 ] {d0ae5113-167e-4071-8993-e160153e8093} executeQuery: Code: 36. DB::Exception: Column `some_column` doesn't have TTL, cannot remove it. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41682) (comment: 01493_alter_remove_no_property_zookeeper_long.sql) (query 21, line 44) (in query: ALTER TABLE r_no_prop_table MODIFY COLUMN some_column REMOVE TTL;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1570: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819c671 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:00:57.530850 [ 24860 ] {} TCPHandler: Code: 36. DB::Exception: Column `some_column` doesn't have TTL, cannot remove it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1570: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819c671 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:00:57.557717 [ 24860 ] {31bc7c9d-17c0-409e-a43c-b082089e1c25} executeQuery: Code: 36. DB::Exception: Table doesn't have any table TTL expression, cannot remove. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41682) (comment: 01493_alter_remove_no_property_zookeeper_long.sql) (query 22, line 46) (in query: ALTER TABLE r_no_prop_table REMOVE TTL;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/AlterCommands.cpp:1709: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000038198ded 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:00:57.563832 [ 24860 ] {} TCPHandler: Code: 36. DB::Exception: Table doesn't have any table TTL expression, cannot remove. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/AlterCommands.cpp:1709: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000038198ded 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:00:57.646283 [ 24860 ] {92f3d6c3-fa26-485a-885d-aed064da7316} executeQuery: Code: 36. DB::Exception: Column `some_column` doesn't have TTL, cannot remove it. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41682) (comment: 01493_alter_remove_no_property_zookeeper_long.sql) (query 24, line 50) (in query: ALTER TABLE r_no_prop_table MODIFY COLUMN some_column REMOVE ttl;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1570: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819c671 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:00:57.652859 [ 24860 ] {} TCPHandler: Code: 36. DB::Exception: Column `some_column` doesn't have TTL, cannot remove it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1570: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819c671 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:00:57.679664 [ 24860 ] {978bcb84-01a7-41fb-bf64-06b52184ab5b} executeQuery: Code: 36. DB::Exception: Table doesn't have any table TTL expression, cannot remove. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41682) (comment: 01493_alter_remove_no_property_zookeeper_long.sql) (query 25, line 51) (in query: ALTER TABLE r_no_prop_table remove TTL;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/AlterCommands.cpp:1709: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000038198ded 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:00:57.685142 [ 24860 ] {} TCPHandler: Code: 36. DB::Exception: Table doesn't have any table TTL expression, cannot remove. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/AlterCommands.cpp:1709: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000038198ded 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:01:03.464308 [ 2137 ] {da72ee0f-6c9b-4742-8d02-a607713cd6ca} executeQuery: Code: 1. DB::Exception: JOIN FULL OUTER JOIN ... USING (t) using identifier 't' must be resolved into column node from left table expression. In scope SELECT t AS e, toTypeName(e) FROM nnna FULL OUTER JOIN nnnb USING (t). (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58690) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (query 116, line 175) (in query: SELECT t as e, toTypeName(e) FROM nnna FULL JOIN nnnb USING (t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000303de2b7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5264: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303d42b2 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f5a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 09:01:03.471438 [ 2137 ] {} TCPHandler: Code: 1. DB::Exception: JOIN FULL OUTER JOIN ... USING (t) using identifier 't' must be resolved into column node from left table expression. In scope SELECT t AS e, toTypeName(e) FROM nnna FULL OUTER JOIN nnnb USING (t). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000303de2b7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5264: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303d42b2 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f5a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 09:01:03.535327 [ 2137 ] {79a4d63c-6c92-4999-a653-89c21ec0d5c3} executeQuery: Code: 1. DB::Exception: JOIN FULL OUTER JOIN ... USING (t) using identifier 't' must be resolved into column node from left table expression. In scope SELECT t.t AS e, toTypeName(e) FROM nnna FULL OUTER JOIN nnnb USING (t). (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58690) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (query 117, line 176) (in query: SELECT t.t as e, toTypeName(e) FROM nnna FULL JOIN nnnb USING (t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000303de2b7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5264: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303d42b2 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f5a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 09:01:03.542222 [ 2137 ] {} TCPHandler: Code: 1. DB::Exception: JOIN FULL OUTER JOIN ... USING (t) using identifier 't' must be resolved into column node from left table expression. In scope SELECT t.t AS e, toTypeName(e) FROM nnna FULL OUTER JOIN nnnb USING (t). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000303de2b7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5264: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303d42b2 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f5a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 09:01:03.597400 [ 2137 ] {2f4249a5-a5dd-4b68-a516-576ff0dedb03} executeQuery: Code: 1. DB::Exception: JOIN FULL OUTER JOIN ... USING (t) using identifier 't' must be resolved into column node from left table expression. In scope SELECT t.t.t AS e, toTypeName(e) FROM nnna FULL OUTER JOIN nnnb USING (t). (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58690) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (query 118, line 177) (in query: SELECT t.t.t as e, toTypeName(e) FROM nnna FULL JOIN nnnb USING (t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000303de2b7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5264: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303d42b2 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f5a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 09:01:03.604515 [ 2137 ] {} TCPHandler: Code: 1. DB::Exception: JOIN FULL OUTER JOIN ... USING (t) using identifier 't' must be resolved into column node from left table expression. In scope SELECT t.t.t AS e, toTypeName(e) FROM nnna FULL OUTER JOIN nnnb USING (t). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000303de2b7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5264: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303d42b2 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f5a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 09:01:03.675434 [ 2137 ] {dba39c89-551e-42a8-9ec0-7d1545e3e77f} executeQuery: Code: 1. DB::Exception: JOIN FULL OUTER JOIN ... USING (t) using identifier 't' must be resolved into column node from left table expression. In scope SELECT t.t.t.t.t AS e, toTypeName(e) FROM nnna FULL OUTER JOIN nnnb USING (t). (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58690) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (query 119, line 178) (in query: SELECT t.t.t.t.t as e, toTypeName(e) FROM nnna FULL JOIN nnnb USING (t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000303de2b7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5264: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303d42b2 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f5a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 09:01:03.685074 [ 2137 ] {} TCPHandler: Code: 1. DB::Exception: JOIN FULL OUTER JOIN ... USING (t) using identifier 't' must be resolved into column node from left table expression. In scope SELECT t.t.t.t.t AS e, toTypeName(e) FROM nnna FULL OUTER JOIN nnnb USING (t). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000303de2b7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5264: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303d42b2 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f5a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 09:01:03.749456 [ 2137 ] {a1ef95b9-8ebb-4fe9-8c6f-c274f59ee029} executeQuery: Code: 207. DB::Exception: Cannot select subcolumn for identifier 't' while joining using column 't.t'. (AMBIGUOUS_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58690) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (query 120, line 180) (in query: SELECT t as e, toTypeName(e) FROM nnna FULL JOIN nnnb USING (t.t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x0000000031049c8d 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:926: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x000000003103c85e 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:965: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000310396b7 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003103680c 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000031044302 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b991 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 09:01:03.756302 [ 2137 ] {} TCPHandler: Code: 207. DB::Exception: Cannot select subcolumn for identifier 't' while joining using column 't.t'. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x0000000031049c8d 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:926: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x000000003103c85e 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:965: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000310396b7 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003103680c 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000031044302 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b991 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 09:01:04.839959 [ 2137 ] {92e8d241-c16e-49c7-ad2f-472fecc7b8e6} executeQuery: Code: 207. DB::Exception: Cannot select subcolumn for identifier 't' while joining using column 't.t'. (AMBIGUOUS_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58690) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (query 124, line 185) (in query: SELECT t.*, t.* APPLY toTypeName FROM nnna FULL JOIN nnnb USING (t.t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x0000000031049c8d 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:926: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x000000003103c85e 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:965: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000310396b7 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003103680c 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000031044302 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b991 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1816: DB::QueryAnalyzer::resolveQualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003036a7af 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2204: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303a177a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3800: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030327a79 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 09:01:04.848578 [ 2137 ] {} TCPHandler: Code: 207. DB::Exception: Cannot select subcolumn for identifier 't' while joining using column 't.t'. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x0000000031049c8d 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:926: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x000000003103c85e 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:965: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000310396b7 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003103680c 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000031044302 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b991 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1816: DB::QueryAnalyzer::resolveQualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003036a7af 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2204: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303a177a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3800: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030327a79 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 09:01:05.549864 [ 2085 ] {d6b8d2b1-bb80-41b4-b5c1-53541b72d507} executeQuery: Code: 57. DB::Exception: Table test_qwfsqaty.aine already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59218) (comment: 01073_attach_if_not_exists.sql) (query 2, line 3) (in query: ATTACH TABLE aine;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291ff91 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:01:05.558926 [ 2085 ] {} TCPHandler: Code: 57. DB::Exception: Table test_qwfsqaty.aine already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291ff91 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:01:07.128588 [ 15861 ] {e1a74f37-2c52-491f-a01c-f2fa811a0836} executeQuery: Code: 36. DB::Exception: Setting max_bytes_ratio_before_external_sort should be >= 0 and < 1 (-0.1). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59286) (comment: 03271_max_bytes_ratio_before_external_order_by.sql) (query 1, line 1) (in query: select number from numbers(100e6) order by number format Null settings max_bytes_ratio_before_external_sort=-0.1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, double&) @ 0x000000001aa34f0a 4. ./build_docker/./src/Processors/QueryPlan/SortingStep.cpp:78: DB::getMaxBytesBeforeExternalSort(unsigned long, double) @ 0x000000003c35d15c 5. ./build_docker/./src/Processors/QueryPlan/SortingStep.cpp:109: DB::SortingStep::Settings::Settings(DB::Settings const&) @ 0x000000003c35fbe6 6. ./build_docker/./src/Planner/Planner.cpp:724: DB::(anonymous namespace)::addSortingStep(DB::QueryPlan&, DB::(anonymous namespace)::QueryAnalysisResult const&, std::shared_ptr const&) @ 0x0000000032b1a06c 7. ./build_docker/./src/Planner/Planner.cpp:1795: DB::Planner::buildPlanForQueryNode() @ 0x0000000032b04c3d 8. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:01:07.135744 [ 15861 ] {} TCPHandler: Code: 36. DB::Exception: Setting max_bytes_ratio_before_external_sort should be >= 0 and < 1 (-0.1). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, double&) @ 0x000000001aa34f0a 4. ./build_docker/./src/Processors/QueryPlan/SortingStep.cpp:78: DB::getMaxBytesBeforeExternalSort(unsigned long, double) @ 0x000000003c35d15c 5. ./build_docker/./src/Processors/QueryPlan/SortingStep.cpp:109: DB::SortingStep::Settings::Settings(DB::Settings const&) @ 0x000000003c35fbe6 6. ./build_docker/./src/Planner/Planner.cpp:724: DB::(anonymous namespace)::addSortingStep(DB::QueryPlan&, DB::(anonymous namespace)::QueryAnalysisResult const&, std::shared_ptr const&) @ 0x0000000032b1a06c 7. ./build_docker/./src/Planner/Planner.cpp:1795: DB::Planner::buildPlanForQueryNode() @ 0x0000000032b04c3d 8. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:01:07.204470 [ 15861 ] {12f45eee-943a-41d7-ac4f-85a3a1c26376} executeQuery: Code: 36. DB::Exception: Setting max_bytes_ratio_before_external_sort should be >= 0 and < 1 (1). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59286) (comment: 03271_max_bytes_ratio_before_external_order_by.sql) (query 2, line 2) (in query: select number from numbers(100e6) order by number format Null settings max_bytes_ratio_before_external_sort=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, double&) @ 0x000000001aa34f0a 4. ./build_docker/./src/Processors/QueryPlan/SortingStep.cpp:78: DB::getMaxBytesBeforeExternalSort(unsigned long, double) @ 0x000000003c35d15c 5. ./build_docker/./src/Processors/QueryPlan/SortingStep.cpp:109: DB::SortingStep::Settings::Settings(DB::Settings const&) @ 0x000000003c35fbe6 6. ./build_docker/./src/Planner/Planner.cpp:724: DB::(anonymous namespace)::addSortingStep(DB::QueryPlan&, DB::(anonymous namespace)::QueryAnalysisResult const&, std::shared_ptr const&) @ 0x0000000032b1a06c 7. ./build_docker/./src/Planner/Planner.cpp:1795: DB::Planner::buildPlanForQueryNode() @ 0x0000000032b04c3d 8. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:01:07.211890 [ 15861 ] {} TCPHandler: Code: 36. DB::Exception: Setting max_bytes_ratio_before_external_sort should be >= 0 and < 1 (1). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, double&) @ 0x000000001aa34f0a 4. ./build_docker/./src/Processors/QueryPlan/SortingStep.cpp:78: DB::getMaxBytesBeforeExternalSort(unsigned long, double) @ 0x000000003c35d15c 5. ./build_docker/./src/Processors/QueryPlan/SortingStep.cpp:109: DB::SortingStep::Settings::Settings(DB::Settings const&) @ 0x000000003c35fbe6 6. ./build_docker/./src/Planner/Planner.cpp:724: DB::(anonymous namespace)::addSortingStep(DB::QueryPlan&, DB::(anonymous namespace)::QueryAnalysisResult const&, std::shared_ptr const&) @ 0x0000000032b1a06c 7. ./build_docker/./src/Planner/Planner.cpp:1795: DB::Planner::buildPlanForQueryNode() @ 0x0000000032b04c3d 8. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:01:08.976354 [ 2137 ] {8f117a7a-8546-4b3f-8d21-661963032563} executeQuery: Code: 1. DB::Exception: JOIN FULL OUTER JOIN ... USING (t) using identifier 't' must be resolved into column node from left table expression. In scope SELECT 1 FROM na FULL OUTER JOIN nb USING (t). (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58690) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (query 141, line 206) (in query: SELECT 1 FROM na FULL JOIN nb USING (t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000303de2b7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5264: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303d42b2 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f5a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 09:01:08.985089 [ 2137 ] {} TCPHandler: Code: 1. DB::Exception: JOIN FULL OUTER JOIN ... USING (t) using identifier 't' must be resolved into column node from left table expression. In scope SELECT 1 FROM na FULL OUTER JOIN nb USING (t). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000303de2b7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5264: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303d42b2 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f5a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 09:01:09.895328 [ 9254 ] {5c79b4a5-7c5c-4b5e-9baa-083ce15b4bed} executeQuery: Code: 119. DB::Exception: Table engine is not specified in CREATE query. (ENGINE_REQUIRED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59378) (comment: 02184_default_table_engine.sql) (query 2, line 3) (in query: CREATE TABLE table_02184 (x UInt8);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1170: DB::(anonymous namespace)::setDefaultTableEngine(DB::ASTStorage&, DB::DefaultTableEngine) @ 0x00000000328f4cd8 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1384: DB::InterpreterCreateQuery::setEngine(DB::ASTCreateQuery&) const @ 0x00000000328e95ff 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:761: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000328d51d2 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000328fff5d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:01:09.901129 [ 9254 ] {} TCPHandler: Code: 119. DB::Exception: Table engine is not specified in CREATE query. (ENGINE_REQUIRED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1170: DB::(anonymous namespace)::setDefaultTableEngine(DB::ASTStorage&, DB::DefaultTableEngine) @ 0x00000000328f4cd8 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1384: DB::InterpreterCreateQuery::setEngine(DB::ASTCreateQuery&) const @ 0x00000000328e95ff 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:761: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000328d51d2 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000328fff5d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:01:10.113975 [ 2137 ] {4f4565a4-40a0-4b47-a457-966e94d32356} executeQuery: Code: 207. DB::Exception: Cannot select subcolumn for identifier 't' while joining using column 't.t'. (AMBIGUOUS_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58690) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (query 150, line 220) (in query: SELECT t FROM na FULL JOIN nb USING (t.t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x0000000031049c8d 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:926: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x000000003103c85e 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:965: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000310396b7 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003103680c 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000031044302 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b991 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 09:01:10.120318 [ 2137 ] {} TCPHandler: Code: 207. DB::Exception: Cannot select subcolumn for identifier 't' while joining using column 't.t'. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x0000000031049c8d 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:926: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x000000003103c85e 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:965: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000310396b7 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003103680c 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000031044302 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b991 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 09:01:10.413295 [ 9254 ] {f648d99b-7d14-4f6f-a1f3-51b3c6a49950} executeQuery: Code: 42. DB::Exception: ORDER BY or PRIMARY KEY clause is missing. Consider using extended storage definition syntax with ORDER BY or PRIMARY KEY clause. With deprecated old syntax (highly not recommended) storage MergeTree requires 3 to 4 parameters: name of column with date, [sampling element of primary key], primary key expression, index granularity Syntax for the MergeTree table engine: CREATE TABLE [IF NOT EXISTS] [db.]table_name [ON CLUSTER cluster] ( name1 [type1] [DEFAULT|MATERIALIZED|ALIAS expr1] [TTL expr1], name2 [type2] [DEFAULT|MATERIALIZED|ALIAS expr2] [TTL expr2], ... INDEX index_name1 expr1 TYPE type1(...) [GRANULARITY value1], INDEX index_name2 expr2 TYPE type2(...) [GRANULARITY value2] ) ENGINE = MergeTree() ORDER BY expr [PARTITION BY expr] [PRIMARY KEY expr] [SAMPLE BY expr] [TTL expr [DELETE|TO DISK 'xxx'|TO VOLUME 'xxx'], ...] [SETTINGS name=value, ...] [COMMENT 'comment'] See details in documentation: https://clickhouse.com/docs/engines/table-engines/mergetree-family/mergetree/. Other engines of the family support different syntax, see details in the corresponding documentation topics. If you use the Replicated version of engines, see https://clickhouse.com/docs/engines/table-engines/mergetree-family/replication/. . (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59378) (comment: 02184_default_table_engine.sql) (query 8, line 10) (in query: CREATE TABLE table_02184 (x UInt8);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&, char const* const&) @ 0x000000003a38a377 4. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:502: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a3837a2 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:01:10.420419 [ 9254 ] {} TCPHandler: Code: 42. DB::Exception: ORDER BY or PRIMARY KEY clause is missing. Consider using extended storage definition syntax with ORDER BY or PRIMARY KEY clause. With deprecated old syntax (highly not recommended) storage MergeTree requires 3 to 4 parameters: name of column with date, [sampling element of primary key], primary key expression, index granularity Syntax for the MergeTree table engine: CREATE TABLE [IF NOT EXISTS] [db.]table_name [ON CLUSTER cluster] ( name1 [type1] [DEFAULT|MATERIALIZED|ALIAS expr1] [TTL expr1], name2 [type2] [DEFAULT|MATERIALIZED|ALIAS expr2] [TTL expr2], ... INDEX index_name1 expr1 TYPE type1(...) [GRANULARITY value1], INDEX index_name2 expr2 TYPE type2(...) [GRANULARITY value2] ) ENGINE = MergeTree() ORDER BY expr [PARTITION BY expr] [PRIMARY KEY expr] [SAMPLE BY expr] [TTL expr [DELETE|TO DISK 'xxx'|TO VOLUME 'xxx'], ...] [SETTINGS name=value, ...] [COMMENT 'comment'] See details in documentation: https://clickhouse.com/docs/engines/table-engines/mergetree-family/mergetree/. Other engines of the family support different syntax, see details in the corresponding documentation topics. If you use the Replicated version of engines, see https://clickhouse.com/docs/engines/table-engines/mergetree-family/replication/. . (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&, char const* const&) @ 0x000000003a38a377 4. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:502: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a3837a2 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:01:10.532471 [ 2137 ] {e83d239e-2d14-420a-a2aa-9a8c45c01a66} executeQuery: Code: 207. DB::Exception: Cannot select subcolumn for identifier 'na.t' while joining using column 't.t'. (AMBIGUOUS_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58690) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (query 153, line 223) (in query: SELECT na.t FROM na FULL JOIN nb USING (t.t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x0000000031049c8d 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:926: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x000000003103c85e 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1027: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003103a131 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003103680c 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000031044302 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b991 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 09:01:10.539049 [ 2137 ] {} TCPHandler: Code: 207. DB::Exception: Cannot select subcolumn for identifier 'na.t' while joining using column 't.t'. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x0000000031049c8d 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:926: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x000000003103c85e 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1027: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003103a131 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003103680c 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000031044302 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b991 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 09:01:10.793898 [ 2137 ] {d0b8c976-fec4-4315-aee1-8a65d1d33308} executeQuery: Code: 207. DB::Exception: Cannot select subcolumn for identifier 'nb.t' while joining using column 't.t'. (AMBIGUOUS_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58690) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (query 155, line 225) (in query: SELECT nb.t FROM na FULL JOIN nb USING (t.t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x0000000031049c8d 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:926: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x000000003103c85e 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1052: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003103a112 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003103680c 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000031044302 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b991 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 09:01:10.800673 [ 2137 ] {} TCPHandler: Code: 207. DB::Exception: Cannot select subcolumn for identifier 'nb.t' while joining using column 't.t'. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x0000000031049c8d 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:926: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x000000003103c85e 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1052: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003103a112 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003103680c 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000031044302 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b991 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 09:01:11.147402 [ 9254 ] {bd5c11be-bb75-4299-a77a-40758483e132} executeQuery: Code: 36. DB::Exception: You must provide an ORDER BY or PRIMARY KEY expression in the table definition. If you don't want this table to be sorted, use ORDER BY/PRIMARY KEY (). Otherwise, you can use the setting 'create_table_empty_primary_key_by_default' to automatically add an empty primary key to the table definition. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59378) (comment: 02184_default_table_engine.sql) (query 15, line 18) (in query: CREATE TABLE table_02184 (x UInt8) PARTITION BY x;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:655: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a383a8e 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:01:11.154897 [ 9254 ] {} TCPHandler: Code: 36. DB::Exception: You must provide an ORDER BY or PRIMARY KEY expression in the table definition. If you don't want this table to be sorted, use ORDER BY/PRIMARY KEY (). Otherwise, you can use the setting 'create_table_empty_primary_key_by_default' to automatically add an empty primary key to the table definition. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:655: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a383a8e 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:01:12.027615 [ 410 ] {} CgroupsReader: Cannot find 'kernel' in '/sys/fs/cgroup/memory.stat' (skipped 5910 similar messages) 2025.06.13 09:01:14.297182 [ 2137 ] {13feb538-2f35-467f-bc4e-2db936e5affb} executeQuery: Code: 207. DB::Exception: Cannot select subcolumn for identifier 't.t' while joining using column 't'. (AMBIGUOUS_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58690) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (query 174, line 251) (in query: SELECT t.t FROM (SELECT (1, 's') :: Tuple(t Int32, s String) as t ) as na FULL JOIN (SELECT (1, 's') :: Tuple(t UInt32, s String) as t ) as nb USING (t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x0000000031049c8d 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:926: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x000000003103c85e 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:965: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000310396b7 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003103680c 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000031044302 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b991 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 09:01:14.304615 [ 2137 ] {} TCPHandler: Code: 207. DB::Exception: Cannot select subcolumn for identifier 't.t' while joining using column 't'. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x0000000031049c8d 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:926: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x000000003103c85e 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:965: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000310396b7 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003103680c 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000031044302 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b991 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 09:01:14.387490 [ 2137 ] {1de005f3-0fba-43cc-8985-b650c5080815} executeQuery: Code: 1. DB::Exception: JOIN FULL OUTER JOIN ... USING (t.t) using identifier 't.t' must be resolved into column node from left table expression. In scope SELECT * FROM (SELECT CAST('(1, \'s\')', 'Tuple(t Int32, s String)') AS t) AS na FULL OUTER JOIN (SELECT CAST('(1, \'s\')', 'Tuple(t UInt32, s String)') AS t) AS nb USING (t.t). (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58690) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (query 175, line 252) (in query: SELECT * FROM (SELECT (1, 's') :: Tuple(t Int32, s String) as t ) as na FULL JOIN (SELECT (1, 's') :: Tuple(t UInt32, s String) as t ) as nb USING (t.t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000303de2b7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5264: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303d42b2 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f5a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 09:01:14.394432 [ 2137 ] {} TCPHandler: Code: 1. DB::Exception: JOIN FULL OUTER JOIN ... USING (t.t) using identifier 't.t' must be resolved into column node from left table expression. In scope SELECT * FROM (SELECT CAST('(1, \'s\')', 'Tuple(t Int32, s String)') AS t) AS na FULL OUTER JOIN (SELECT CAST('(1, \'s\')', 'Tuple(t UInt32, s String)') AS t) AS nb USING (t.t). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000303de2b7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5264: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303d42b2 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f5a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 09:01:14.469180 [ 2137 ] {ff6c5668-c72d-4c93-a9aa-c72b7731de6c} executeQuery: Code: 1. DB::Exception: JOIN FULL OUTER JOIN ... USING (t.t) using identifier 't.t' must be resolved into column node from left table expression. In scope SELECT t AS e, toTypeName(e) FROM (SELECT CAST('((((1, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String)') AS t) AS ttta FULL OUTER JOIN (SELECT CAST('((((2, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String)') AS t) AS tttb USING (t.t). (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58690) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (query 176, line 254) (in query: SELECT t as e, toTypeName(e) FROM ( SELECT ((((1, 's'), 's'), 's'), 's') :: Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String) as t ) ttta FULL JOIN ( SELECT ((((2, 's'), 's'), 's'), 's') :: Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String) as t ) tttb USING (t.t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000303de2b7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5264: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303d42b2 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f5a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 09:01:14.476480 [ 2137 ] {} TCPHandler: Code: 1. DB::Exception: JOIN FULL OUTER JOIN ... USING (t.t) using identifier 't.t' must be resolved into column node from left table expression. In scope SELECT t AS e, toTypeName(e) FROM (SELECT CAST('((((1, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String)') AS t) AS ttta FULL OUTER JOIN (SELECT CAST('((((2, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String)') AS t) AS tttb USING (t.t). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000303de2b7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5264: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303d42b2 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f5a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 09:01:14.558888 [ 2137 ] {8356d705-7d90-4239-bc86-409b89c89030} executeQuery: Code: 1. DB::Exception: JOIN FULL OUTER JOIN ... USING (t.t) using identifier 't.t' must be resolved into column node from left table expression. In scope SELECT t.t AS e, toTypeName(e) FROM (SELECT CAST('((((1, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String)') AS t) AS ttta FULL OUTER JOIN (SELECT CAST('((((2, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String)') AS t) AS tttb USING (t.t). (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58690) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (query 177, line 260) (in query: SELECT t.t as e, toTypeName(e) FROM ( SELECT ((((1, 's'), 's'), 's'), 's') :: Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String) as t ) ttta FULL JOIN ( SELECT ((((2, 's'), 's'), 's'), 's') :: Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String) as t ) tttb USING (t.t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000303de2b7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5264: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303d42b2 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f5a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 09:01:14.567542 [ 2137 ] {} TCPHandler: Code: 1. DB::Exception: JOIN FULL OUTER JOIN ... USING (t.t) using identifier 't.t' must be resolved into column node from left table expression. In scope SELECT t.t AS e, toTypeName(e) FROM (SELECT CAST('((((1, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String)') AS t) AS ttta FULL OUTER JOIN (SELECT CAST('((((2, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String)') AS t) AS tttb USING (t.t). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000303de2b7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5264: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303d42b2 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f5a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 09:01:14.644580 [ 2137 ] {e7d19154-4a7a-4f12-b984-340ff134a148} executeQuery: Code: 1. DB::Exception: JOIN FULL OUTER JOIN ... USING (t.t) using identifier 't.t' must be resolved into column node from left table expression. In scope SELECT t.t.t AS e, toTypeName(e) FROM (SELECT CAST('((((1, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String)') AS t) AS ttta FULL OUTER JOIN (SELECT CAST('((((2, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String)') AS t) AS tttb USING (t.t). (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58690) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (query 178, line 266) (in query: SELECT t.t.t as e, toTypeName(e) FROM ( SELECT ((((1, 's'), 's'), 's'), 's') :: Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String) as t ) ttta FULL JOIN ( SELECT ((((2, 's'), 's'), 's'), 's') :: Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String) as t ) tttb USING (t.t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000303de2b7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5264: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303d42b2 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f5a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 09:01:14.652487 [ 2137 ] {} TCPHandler: Code: 1. DB::Exception: JOIN FULL OUTER JOIN ... USING (t.t) using identifier 't.t' must be resolved into column node from left table expression. In scope SELECT t.t.t AS e, toTypeName(e) FROM (SELECT CAST('((((1, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String)') AS t) AS ttta FULL OUTER JOIN (SELECT CAST('((((2, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String)') AS t) AS tttb USING (t.t). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000303de2b7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5264: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303d42b2 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f5a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 09:01:14.928855 [ 2137 ] {3f33fe0f-c537-4eb2-88a7-b68eb7fb28ce} executeQuery: Code: 207. DB::Exception: Cannot select subcolumn for identifier 't.t' while joining using column 't'. (AMBIGUOUS_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58690) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (query 180, line 278) (in query: SELECT t.t as e, toTypeName(e) FROM ( SELECT ((((1, 's'), 's'), 's'), 's') :: Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String) as t ) ttta FULL JOIN ( SELECT ((((2, 's'), 's'), 's'), 's') :: Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String) as t ) tttb USING (t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x0000000031049c8d 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:926: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x000000003103c85e 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:965: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000310396b7 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003103680c 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000031044302 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b991 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 09:01:14.936178 [ 2137 ] {} TCPHandler: Code: 207. DB::Exception: Cannot select subcolumn for identifier 't.t' while joining using column 't'. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x0000000031049c8d 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:926: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x000000003103c85e 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:965: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000310396b7 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003103680c 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000031044302 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b991 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 09:01:15.593479 [ 9254 ] {6d6eb123-77ab-4df1-9a20-5b4828cc83af} executeQuery: Code: 37. DB::Exception: Database engine `Atomic` cannot have parameters, primary_key, order_by, sample_by, settings. (UNKNOWN_ELEMENT_IN_AST) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59378) (comment: 02184_default_table_engine.sql) (query 58, line 70) (in query: CREATE DATABASE test_02184 ORDER BY kek;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Databases/DatabaseFactory.cpp:86: DB::DatabaseFactory::validate(DB::ASTCreateQuery const&) const @ 0x000000002f82fbf5 5. ./build_docker/./src/Databases/DatabaseFactory.cpp:108: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x000000002f830316 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:341: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000328bbd02 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3a0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:01:15.600558 [ 9254 ] {} TCPHandler: Code: 37. DB::Exception: Database engine `Atomic` cannot have parameters, primary_key, order_by, sample_by, settings. (UNKNOWN_ELEMENT_IN_AST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Databases/DatabaseFactory.cpp:86: DB::DatabaseFactory::validate(DB::ASTCreateQuery const&) const @ 0x000000002f82fbf5 5. ./build_docker/./src/Databases/DatabaseFactory.cpp:108: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x000000002f830316 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:341: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000328bbd02 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3a0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:01:15.779760 [ 9254 ] {} TCPHandler: Code: 115. DB::Exception: Setting x is neither a builtin setting nor started with the prefix 'SQL_' or 'custom_' registered for user-defined settings. (UNKNOWN_SETTING), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Access/AccessControl.cpp:134: DB::AccessControl::CustomSettingsPrefixes::checkSettingNameIsAllowed(std::basic_string_view>) const @ 0x000000002e1ad6cb 5. ./build_docker/./src/Access/AccessControl.cpp:686: DB::AccessControl::checkSettingNameIsAllowed(std::basic_string_view>) const @ 0x000000002e1a9f06 6. ./build_docker/./src/Access/SettingsConstraints.cpp:279: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e5fb155 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e5fbbde 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000316f4b4e 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000316f5cb0 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x000000003add1a84 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003adb6f72 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x000000003ad8c9f4 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:01:15.780674 [ 9254 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003adb75b3 5. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x000000003ad8c9f4 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:01:16.882150 [ 15838 ] {1d83e7dc-7c5d-45e6-b39c-08941328dda3} executeQuery: Code: 36. DB::Exception: Engine Memory doesn't support PARTITION_BY, PRIMARY_KEY, ORDER_BY or SAMPLE_BY clauses. Currently only the following engines have support for the feature: [OSS, AzureBlobStorage, KeeperMap, S3, MaterializedPostgreSQL, COSN, Redis, ReplicatedSummingMergeTree, Hive, ReplicatedVersionedCollapsingMergeTree, VersionedCollapsingMergeTree, ReplacingMergeTree, HDFS, EmbeddedRocksDB, ReplicatedCollapsingMergeTree, ReplicatedGraphiteMergeTree, ReplicatedMergeTree, ReplicatedReplacingMergeTree, SummingMergeTree, MergeTree, GraphiteMergeTree, CollapsingMergeTree, ReplicatedAggregatingMergeTree, AggregatingMergeTree]. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60492) (comment: 02184_default_table_engine.sql) (query 72, line 88) (in query: CREATE TEMPORARY TABLE tmp2 (n int) ORDER BY n;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&) @ 0x000000002009adf7 4. ./build_docker/./src/Storages/StorageFactory.cpp:187: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const::$_0::operator()(String, std::function) const @ 0x00000000383eb343 5. ./build_docker/./src/Storages/StorageFactory.cpp:199: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000383e89af 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1768: std::shared_ptr std::__function::__policy_invoker (DB::StorageID const&)>::__call_impl[abi:ne190107]>&, DB::LoadingStrictnessLevel)::$_0, std::shared_ptr (DB::StorageID const&)>>(std::__function::__policy_storage const*, DB::StorageID const&) @ 0x000000003293116c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000319eb96e 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1776: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032915eb5 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 09:01:16.888869 [ 15838 ] {} TCPHandler: Code: 36. DB::Exception: Engine Memory doesn't support PARTITION_BY, PRIMARY_KEY, ORDER_BY or SAMPLE_BY clauses. Currently only the following engines have support for the feature: [OSS, AzureBlobStorage, KeeperMap, S3, MaterializedPostgreSQL, COSN, Redis, ReplicatedSummingMergeTree, Hive, ReplicatedVersionedCollapsingMergeTree, VersionedCollapsingMergeTree, ReplacingMergeTree, HDFS, EmbeddedRocksDB, ReplicatedCollapsingMergeTree, ReplicatedGraphiteMergeTree, ReplicatedMergeTree, ReplicatedReplacingMergeTree, SummingMergeTree, MergeTree, GraphiteMergeTree, CollapsingMergeTree, ReplicatedAggregatingMergeTree, AggregatingMergeTree]. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&) @ 0x000000002009adf7 4. ./build_docker/./src/Storages/StorageFactory.cpp:187: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const::$_0::operator()(String, std::function) const @ 0x00000000383eb343 5. ./build_docker/./src/Storages/StorageFactory.cpp:199: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000383e89af 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1768: std::shared_ptr std::__function::__policy_invoker (DB::StorageID const&)>::__call_impl[abi:ne190107]>&, DB::LoadingStrictnessLevel)::$_0, std::shared_ptr (DB::StorageID const&)>>(std::__function::__policy_storage const*, DB::StorageID const&) @ 0x000000003293116c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000319eb96e 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1776: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032915eb5 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 09:01:16.929831 [ 15838 ] {d8ea15a8-72ae-4e26-8f09-5312879f5cbe} executeQuery: Code: 36. DB::Exception: Engine Memory doesn't support PARTITION_BY, PRIMARY_KEY, ORDER_BY or SAMPLE_BY clauses. Currently only the following engines have support for the feature: [OSS, AzureBlobStorage, KeeperMap, S3, MaterializedPostgreSQL, COSN, Redis, ReplicatedSummingMergeTree, Hive, ReplicatedVersionedCollapsingMergeTree, VersionedCollapsingMergeTree, ReplacingMergeTree, HDFS, EmbeddedRocksDB, ReplicatedCollapsingMergeTree, ReplicatedGraphiteMergeTree, ReplicatedMergeTree, ReplicatedReplacingMergeTree, SummingMergeTree, MergeTree, GraphiteMergeTree, CollapsingMergeTree, ReplicatedAggregatingMergeTree, AggregatingMergeTree]. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60492) (comment: 02184_default_table_engine.sql) (query 73, line 89) (in query: CREATE TEMPORARY TABLE tmp2 (n int, PRIMARY KEY (n));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&) @ 0x000000002009adf7 4. ./build_docker/./src/Storages/StorageFactory.cpp:187: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const::$_0::operator()(String, std::function) const @ 0x00000000383eb343 5. ./build_docker/./src/Storages/StorageFactory.cpp:199: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000383e89af 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1768: std::shared_ptr std::__function::__policy_invoker (DB::StorageID const&)>::__call_impl[abi:ne190107]>&, DB::LoadingStrictnessLevel)::$_0, std::shared_ptr (DB::StorageID const&)>>(std::__function::__policy_storage const*, DB::StorageID const&) @ 0x000000003293116c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000319eb96e 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1776: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032915eb5 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 09:01:16.939554 [ 15838 ] {} TCPHandler: Code: 36. DB::Exception: Engine Memory doesn't support PARTITION_BY, PRIMARY_KEY, ORDER_BY or SAMPLE_BY clauses. Currently only the following engines have support for the feature: [OSS, AzureBlobStorage, KeeperMap, S3, MaterializedPostgreSQL, COSN, Redis, ReplicatedSummingMergeTree, Hive, ReplicatedVersionedCollapsingMergeTree, VersionedCollapsingMergeTree, ReplacingMergeTree, HDFS, EmbeddedRocksDB, ReplicatedCollapsingMergeTree, ReplicatedGraphiteMergeTree, ReplicatedMergeTree, ReplicatedReplacingMergeTree, SummingMergeTree, MergeTree, GraphiteMergeTree, CollapsingMergeTree, ReplicatedAggregatingMergeTree, AggregatingMergeTree]. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&) @ 0x000000002009adf7 4. ./build_docker/./src/Storages/StorageFactory.cpp:187: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const::$_0::operator()(String, std::function) const @ 0x00000000383eb343 5. ./build_docker/./src/Storages/StorageFactory.cpp:199: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000383e89af 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1768: std::shared_ptr std::__function::__policy_invoker (DB::StorageID const&)>::__call_impl[abi:ne190107]>&, DB::LoadingStrictnessLevel)::$_0, std::shared_ptr (DB::StorageID const&)>>(std::__function::__policy_storage const*, DB::StorageID const&) @ 0x000000003293116c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000319eb96e 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1776: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032915eb5 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 09:01:17.669526 [ 15838 ] {5e203ba0-0a8e-42b5-9cf5-f36f8d9e0887} executeQuery: Code: 119. DB::Exception: Table engine is not specified in CREATE query. (ENGINE_REQUIRED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60492) (comment: 02184_default_table_engine.sql) (query 85, line 103) (in query: CREATE TABLE mem AS SELECT 1 as n;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1170: DB::(anonymous namespace)::setDefaultTableEngine(DB::ASTStorage&, DB::DefaultTableEngine) @ 0x00000000328f4cd8 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1384: DB::InterpreterCreateQuery::setEngine(DB::ASTCreateQuery&) const @ 0x00000000328e95ff 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:761: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000328d51d2 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000328fff5d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:01:17.676744 [ 15838 ] {} TCPHandler: Code: 119. DB::Exception: Table engine is not specified in CREATE query. (ENGINE_REQUIRED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1170: DB::(anonymous namespace)::setDefaultTableEngine(DB::ASTStorage&, DB::DefaultTableEngine) @ 0x00000000328f4cd8 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1384: DB::InterpreterCreateQuery::setEngine(DB::ASTCreateQuery&) const @ 0x00000000328e95ff 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:761: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000328d51d2 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000328fff5d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:01:17.926162 [ 15838 ] {f8594867-06a3-443f-8c50-cadb08ec60f1} executeQuery: Code: 36. DB::Exception: Engine Memory doesn't support PARTITION_BY, PRIMARY_KEY, ORDER_BY or SAMPLE_BY clauses. Currently only the following engines have support for the feature: [OSS, AzureBlobStorage, KeeperMap, S3, MaterializedPostgreSQL, COSN, Redis, ReplicatedSummingMergeTree, Hive, ReplicatedVersionedCollapsingMergeTree, VersionedCollapsingMergeTree, ReplacingMergeTree, HDFS, EmbeddedRocksDB, ReplicatedCollapsingMergeTree, ReplicatedGraphiteMergeTree, ReplicatedMergeTree, ReplicatedReplacingMergeTree, SummingMergeTree, MergeTree, GraphiteMergeTree, CollapsingMergeTree, ReplicatedAggregatingMergeTree, AggregatingMergeTree]. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60492) (comment: 02184_default_table_engine.sql) (query 87, line 105) (in query: CREATE TABLE mem ORDER BY n AS SELECT 1 as n;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&) @ 0x000000002009adf7 4. ./build_docker/./src/Storages/StorageFactory.cpp:187: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const::$_0::operator()(String, std::function) const @ 0x00000000383eb343 5. ./build_docker/./src/Storages/StorageFactory.cpp:199: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000383e89af 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:01:17.933471 [ 15838 ] {} TCPHandler: Code: 36. DB::Exception: Engine Memory doesn't support PARTITION_BY, PRIMARY_KEY, ORDER_BY or SAMPLE_BY clauses. Currently only the following engines have support for the feature: [OSS, AzureBlobStorage, KeeperMap, S3, MaterializedPostgreSQL, COSN, Redis, ReplicatedSummingMergeTree, Hive, ReplicatedVersionedCollapsingMergeTree, VersionedCollapsingMergeTree, ReplacingMergeTree, HDFS, EmbeddedRocksDB, ReplicatedCollapsingMergeTree, ReplicatedGraphiteMergeTree, ReplicatedMergeTree, ReplicatedReplacingMergeTree, SummingMergeTree, MergeTree, GraphiteMergeTree, CollapsingMergeTree, ReplicatedAggregatingMergeTree, AggregatingMergeTree]. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&) @ 0x000000002009adf7 4. ./build_docker/./src/Storages/StorageFactory.cpp:187: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const::$_0::operator()(String, std::function) const @ 0x00000000383eb343 5. ./build_docker/./src/Storages/StorageFactory.cpp:199: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000383e89af 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:01:25.102784 [ 1019 ] {} 7972f75f-c694-4654-a402-1d6a0ea6acc0::all_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1 :: 3) -> throwIf(1) UInt8 : 5'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b0f6008 18. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1247: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039f9797c 19. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1162: DB::PartMergerWriter::execute() @ 0x000000003a003ab3 20. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1394: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ff2c32 21. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2113: DB::MutateTask::execute() @ 0x0000000039fa303f 22. ./src/Storages/MergeTree/MutateFromLogEntryTask.h:46: DB::MutateFromLogEntryTask::executeInnerTask() @ 0x0000000039f8e2c6 23. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:217: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1135ef 24. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:01:25.104182 [ 1019 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7972f75f-c694-4654-a402-1d6a0ea6acc0::all_0_0_0_1}: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1 :: 3) -> throwIf(1) UInt8 : 5'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a98bd03 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b0f6008 18. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1247: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039f9797c 19. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1162: DB::PartMergerWriter::execute() @ 0x000000003a003ab3 20. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1394: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ff2c32 21. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2113: DB::MutateTask::execute() @ 0x0000000039fa303f 22. ./src/Storages/MergeTree/MutateFromLogEntryTask.h:46: DB::MutateFromLogEntryTask::executeInnerTask() @ 0x0000000039f8e2c6 23. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:217: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1135ef 24. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:01:25.486222 [ 9260 ] {b57e6e99-fe9c-41c9-805a-83790424d704} executeQuery: Code: 36. DB::Exception: Cannot drop column x because it's affected by mutation with ID '0000000001' which is not finished yet. Wait this mutation, or KILL it with command "KILL MUTATION WHERE mutation_id = '0000000001'". (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39458) (comment: 02597_column_update_tricky_expression_and_replication.sql) (query 7, line 21) (in query: ALTER TABLE test DROP COLUMN x SETTINGS mutations_sync=2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::MergeTreeData::checkDropCommandDoesntAffectInProgressMutations(DB::AlterCommand const&, std::map, std::allocator>> const&, std::shared_ptr) const @ 0x000000003982b5fd 3. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3638: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003981bc22 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:01:25.492136 [ 9260 ] {} TCPHandler: Code: 36. DB::Exception: Cannot drop column x because it's affected by mutation with ID '0000000001' which is not finished yet. Wait this mutation, or KILL it with command "KILL MUTATION WHERE mutation_id = '0000000001'". (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::MergeTreeData::checkDropCommandDoesntAffectInProgressMutations(DB::AlterCommand const&, std::map, std::allocator>> const&, std::shared_ptr) const @ 0x000000003982b5fd 3. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3638: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003981bc22 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:01:25.594997 [ 1015 ] {} test_gr8q5td0.test (ReplicatedMergeTreeQueue): Mutation with version 1 not found in partition ID all (trying to mutate part all_0_0_0) 2025.06.13 09:01:25.622316 [ 2137 ] {8e40b632-aa96-48fb-ac80-b77cf4e82696} executeQuery: Code: 1. DB::Exception: JOIN FULL OUTER JOIN ... USING (t) using identifier 't' must be resolved into column node from left table expression. In scope SELECT t AS e, toTypeName(e) FROM nnna FULL OUTER JOIN nnnb USING (t). (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58690) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (query 232, line 347) (in query: SELECT t as e, toTypeName(e) FROM nnna FULL JOIN nnnb USING (t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000303de2b7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5264: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303d42b2 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f5a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 09:01:25.630000 [ 2137 ] {} TCPHandler: Code: 1. DB::Exception: JOIN FULL OUTER JOIN ... USING (t) using identifier 't' must be resolved into column node from left table expression. In scope SELECT t AS e, toTypeName(e) FROM nnna FULL OUTER JOIN nnnb USING (t). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000303de2b7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5264: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303d42b2 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f5a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 09:01:25.690349 [ 2137 ] {9ffa909b-37be-4678-af88-628c72a952fb} executeQuery: Code: 1. DB::Exception: JOIN FULL OUTER JOIN ... USING (t) using identifier 't' must be resolved into column node from left table expression. In scope SELECT t.t AS e, toTypeName(e) FROM nnna FULL OUTER JOIN nnnb USING (t). (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58690) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (query 233, line 348) (in query: SELECT t.t as e, toTypeName(e) FROM nnna FULL JOIN nnnb USING (t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000303de2b7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5264: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303d42b2 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f5a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 09:01:25.698922 [ 2137 ] {} TCPHandler: Code: 1. DB::Exception: JOIN FULL OUTER JOIN ... USING (t) using identifier 't' must be resolved into column node from left table expression. In scope SELECT t.t AS e, toTypeName(e) FROM nnna FULL OUTER JOIN nnnb USING (t). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000303de2b7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5264: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303d42b2 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f5a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 09:01:25.772345 [ 2137 ] {a3091fc5-9863-4db7-bdae-400bd096fa58} executeQuery: Code: 1. DB::Exception: JOIN FULL OUTER JOIN ... USING (t) using identifier 't' must be resolved into column node from left table expression. In scope SELECT t.t.t AS e, toTypeName(e) FROM nnna FULL OUTER JOIN nnnb USING (t). (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58690) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (query 234, line 349) (in query: SELECT t.t.t as e, toTypeName(e) FROM nnna FULL JOIN nnnb USING (t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000303de2b7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5264: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303d42b2 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f5a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 09:01:25.781230 [ 2137 ] {} TCPHandler: Code: 1. DB::Exception: JOIN FULL OUTER JOIN ... USING (t) using identifier 't' must be resolved into column node from left table expression. In scope SELECT t.t.t AS e, toTypeName(e) FROM nnna FULL OUTER JOIN nnnb USING (t). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000303de2b7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5264: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303d42b2 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f5a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 09:01:25.841942 [ 2137 ] {9075dcb3-f461-4705-86cf-1aaf96c344ea} executeQuery: Code: 1. DB::Exception: JOIN FULL OUTER JOIN ... USING (t) using identifier 't' must be resolved into column node from left table expression. In scope SELECT t.t.t.t.t AS e, toTypeName(e) FROM nnna FULL OUTER JOIN nnnb USING (t). (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58690) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (query 235, line 350) (in query: SELECT t.t.t.t.t as e, toTypeName(e) FROM nnna FULL JOIN nnnb USING (t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000303de2b7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5264: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303d42b2 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f5a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 09:01:25.849054 [ 2137 ] {} TCPHandler: Code: 1. DB::Exception: JOIN FULL OUTER JOIN ... USING (t) using identifier 't' must be resolved into column node from left table expression. In scope SELECT t.t.t.t.t AS e, toTypeName(e) FROM nnna FULL OUTER JOIN nnnb USING (t). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000303de2b7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5264: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303d42b2 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f5a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 09:01:25.916677 [ 2137 ] {b583d84b-2751-4959-83f7-43d84d2575f2} executeQuery: Code: 207. DB::Exception: Cannot select subcolumn for identifier 't' while joining using column 't.t'. (AMBIGUOUS_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58690) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (query 236, line 352) (in query: SELECT t as e, toTypeName(e) FROM nnna FULL JOIN nnnb USING (t.t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x0000000031049c8d 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:926: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x000000003103c85e 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:965: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000310396b7 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003103680c 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000031044302 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b991 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 09:01:25.923302 [ 2137 ] {} TCPHandler: Code: 207. DB::Exception: Cannot select subcolumn for identifier 't' while joining using column 't.t'. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x0000000031049c8d 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:926: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x000000003103c85e 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:965: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000310396b7 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003103680c 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000031044302 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b991 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030326b5a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 09:01:26.714963 [ 2137 ] {c7dbd323-fdd7-4c79-b4e9-12daa8da13a3} executeQuery: Code: 207. DB::Exception: Cannot select subcolumn for identifier 't' while joining using column 't.t'. (AMBIGUOUS_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58690) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (query 240, line 357) (in query: SELECT t.*, t.* APPLY toTypeName FROM nnna FULL JOIN nnnb USING (t.t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x0000000031049c8d 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:926: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x000000003103c85e 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:965: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000310396b7 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003103680c 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000031044302 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b991 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1816: DB::QueryAnalyzer::resolveQualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003036a7af 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2204: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303a177a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3800: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030327a79 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 09:01:26.723291 [ 2137 ] {} TCPHandler: Code: 207. DB::Exception: Cannot select subcolumn for identifier 't' while joining using column 't.t'. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x0000000031049c8d 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:926: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x000000003103c85e 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:965: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000310396b7 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003103680c 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000031044302 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035b991 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1816: DB::QueryAnalyzer::resolveQualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003036a7af 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2204: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303a177a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3800: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030327a79 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 09:01:28.365003 [ 1386 ] {} test_eep815q0.src2 (49a0fd5d-555a-4965-bbd9-7b25be3c265c): Node with parent zookeeper lock /clickhouse/zero_copy/zero_copy_s3/4f031e0f-7502-4b75-b7c9-b3ba70e818a0/all_0_0_0/s3_jcq_tbcnukymcfxghfhevwksohoahdvmk for part all_0_0_0 doesn't exist (part was unlocked before), refuse to remove blobs 2025.06.13 09:01:28.773737 [ 2136 ] {f9c817c2-19dd-4ca1-a65b-9462fd51d6d5} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 1, should be 2: In scope SELECT max(multiply(1)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39572) (comment: 01323_bad_arg_in_arithmetic_operations.sql) (query 2, line 3) (in query: SELECT max(multiply(1));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 09:01:28.783145 [ 2136 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 1, should be 2: In scope SELECT max(multiply(1)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 09:01:28.822158 [ 2136 ] {780e0275-9a05-482f-b0f8-070f17f65900} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 1, should be 2: In scope SELECT min(multiply(2)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39572) (comment: 01323_bad_arg_in_arithmetic_operations.sql) (query 3, line 4) (in query: SELECT min(multiply(2));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 09:01:28.828466 [ 2136 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 1, should be 2: In scope SELECT min(multiply(2)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 09:01:28.867550 [ 2136 ] {87bd749f-c2a8-42d2-b795-08962af5a679} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 1, should be 2: In scope SELECT sum(multiply(3)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39572) (comment: 01323_bad_arg_in_arithmetic_operations.sql) (query 4, line 5) (in query: SELECT sum(multiply(3));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 09:01:28.873956 [ 2136 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 1, should be 2: In scope SELECT sum(multiply(3)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 09:01:28.912267 [ 2136 ] {171964d6-6b5e-4035-a30a-e4dbfa466ef8} executeQuery: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 1, should be 2: In scope SELECT max(plus(1)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39572) (comment: 01323_bad_arg_in_arithmetic_operations.sql) (query 5, line 7) (in query: SELECT max(plus(1));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 09:01:28.919892 [ 2136 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 1, should be 2: In scope SELECT max(plus(1)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 09:01:28.960873 [ 2136 ] {78183bb6-e183-4ecf-829b-49858b6625cb} executeQuery: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 1, should be 2: In scope SELECT min(plus(2)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39572) (comment: 01323_bad_arg_in_arithmetic_operations.sql) (query 6, line 8) (in query: SELECT min(plus(2));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 09:01:28.968686 [ 2136 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 1, should be 2: In scope SELECT min(plus(2)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 09:01:29.015025 [ 2136 ] {1f276337-9d4e-4e44-b86d-83d7a60eec38} executeQuery: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 1, should be 2: In scope SELECT sum(plus(3)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39572) (comment: 01323_bad_arg_in_arithmetic_operations.sql) (query 7, line 9) (in query: SELECT sum(plus(3));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 09:01:29.022005 [ 2136 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 1, should be 2: In scope SELECT sum(plus(3)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 09:01:29.055334 [ 2136 ] {82f7c077-6f01-43c7-827f-3218adfda272} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 0, should be 2: In scope SELECT max(multiply()). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39572) (comment: 01323_bad_arg_in_arithmetic_operations.sql) (query 8, line 11) (in query: SELECT max(multiply());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 09:01:29.061373 [ 2136 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 0, should be 2: In scope SELECT max(multiply()). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 09:01:29.097659 [ 2136 ] {836d9ad8-0999-4cc2-9464-7abb0f19ccaa} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 3, should be 2: In scope SELECT min(multiply(1, 2, 3)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39572) (comment: 01323_bad_arg_in_arithmetic_operations.sql) (query 9, line 12) (in query: SELECT min(multiply(1, 2 ,3));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 09:01:29.103709 [ 2136 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 3, should be 2: In scope SELECT min(multiply(1, 2, 3)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 09:01:29.398420 [ 2136 ] {b825f6fd-eb86-4343-9042-ba7ff0084623} executeQuery: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 0, should be 2: In scope SELECT sum(plus() + multiply()). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39572) (comment: 01323_bad_arg_in_arithmetic_operations.sql) (query 10, line 13) (in query: SELECT sum(plus() + multiply());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 09:01:29.404898 [ 2136 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 0, should be 2: In scope SELECT sum(plus() + multiply()). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 09:01:29.461881 [ 2136 ] {b761165a-b503-4792-89c5-754ff22bbc13} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 1, should be 2: In scope SELECT sum((42 * 3) + multiply(42)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39572) (comment: 01323_bad_arg_in_arithmetic_operations.sql) (query 11, line 15) (in query: SELECT sum(plus(multiply(42, 3), multiply(42)));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 09:01:29.469852 [ 2136 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 1, should be 2: In scope SELECT sum((42 * 3) + multiply(42)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 09:01:30.686610 [ 2137 ] {00174fcf-c554-47a0-a044-daed53a01b98} executeQuery: Code: 1. DB::Exception: JOIN FULL OUTER JOIN ... USING (t) using identifier 't' must be resolved into column node from left table expression. In scope SELECT 1 FROM na FULL OUTER JOIN nb USING (t). (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58690) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (query 257, line 378) (in query: SELECT 1 FROM na FULL JOIN nb USING (t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000303de2b7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5264: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303d42b2 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f5a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 09:01:30.693121 [ 2137 ] {} TCPHandler: Code: 1. DB::Exception: JOIN FULL OUTER JOIN ... USING (t) using identifier 't' must be resolved into column node from left table expression. In scope SELECT 1 FROM na FULL OUTER JOIN nb USING (t). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000303de2b7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5264: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303d42b2 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f5a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 09:01:36.673355 [ 24843 ] {2b4cb22e-d243-4e29-8294-adb291d182a7} executeQuery: Code: 306. DB::Exception: Maximum parse depth (1000) exceeded. Consider rising max_parser_depth parameter. (TOO_DEEP_RECURSION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:49366) (comment: 00984_parser_stack_overflow.sh) (in query: ((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned int&) @ 0x00000000183a6cca 4. ./src/Parsers/IParser.h:114: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e057d8c 5. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:82: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x000000003e00ed2c 6. ./src/Parsers/ExpressionListParsers.h:89: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003dfeeb70 7. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 8. ./build_docker/./src/Parsers/ParserSelectWithUnionQuery.cpp:15: DB::ParserSelectWithUnionQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e13dc91 9. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 10. ./build_docker/./src/Parsers/ExpressionElementParsers.cpp:116: DB::ParserSubquery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003df8d885 11. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 12. ./build_docker/./src/Parsers/ParserUnionQueryElement.cpp:13: DB::ParserUnionQueryElement::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e1911fb 13. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 14. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:82: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x000000003e00ed2c 15. ./src/Parsers/ExpressionListParsers.h:89: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003dfeeb70 16. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 17. ./build_docker/./src/Parsers/ParserSelectWithUnionQuery.cpp:15: DB::ParserSelectWithUnionQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e13dc91 18. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 19. ./build_docker/./src/Parsers/ExpressionElementParsers.cpp:116: DB::ParserSubquery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003df8d885 20. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 21. ./build_docker/./src/Parsers/ParserUnionQueryElement.cpp:13: DB::ParserUnionQueryElement::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e1911fb 22. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 23. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:82: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x000000003e00ed2c 24. ./src/Parsers/ExpressionListParsers.h:89: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003dfeeb70 25. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 26. ./build_docker/./src/Parsers/ParserSelectWithUnionQuery.cpp:15: DB::ParserSelectWithUnionQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e13dc91 27. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 28. ./build_docker/./src/Parsers/ExpressionElementParsers.cpp:116: DB::ParserSubquery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003df8d885 29. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 30. ./build_docker/./src/Parsers/ParserUnionQueryElement.cpp:13: DB::ParserUnionQueryElement::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e1911fb 31. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 2025.06.13 09:01:36.679546 [ 24843 ] {2b4cb22e-d243-4e29-8294-adb291d182a7} DynamicQueryHandler: Code: 306. DB::Exception: Maximum parse depth (1000) exceeded. Consider rising max_parser_depth parameter. (TOO_DEEP_RECURSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned int&) @ 0x00000000183a6cca 4. ./src/Parsers/IParser.h:114: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e057d8c 5. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:82: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x000000003e00ed2c 6. ./src/Parsers/ExpressionListParsers.h:89: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003dfeeb70 7. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 8. ./build_docker/./src/Parsers/ParserSelectWithUnionQuery.cpp:15: DB::ParserSelectWithUnionQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e13dc91 9. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 10. ./build_docker/./src/Parsers/ExpressionElementParsers.cpp:116: DB::ParserSubquery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003df8d885 11. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 12. ./build_docker/./src/Parsers/ParserUnionQueryElement.cpp:13: DB::ParserUnionQueryElement::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e1911fb 13. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 14. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:82: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x000000003e00ed2c 15. ./src/Parsers/ExpressionListParsers.h:89: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003dfeeb70 16. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 17. ./build_docker/./src/Parsers/ParserSelectWithUnionQuery.cpp:15: DB::ParserSelectWithUnionQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e13dc91 18. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 19. ./build_docker/./src/Parsers/ExpressionElementParsers.cpp:116: DB::ParserSubquery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003df8d885 20. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 21. ./build_docker/./src/Parsers/ParserUnionQueryElement.cpp:13: DB::ParserUnionQueryElement::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e1911fb 22. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 23. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:82: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x000000003e00ed2c 24. ./src/Parsers/ExpressionListParsers.h:89: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003dfeeb70 25. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 26. ./build_docker/./src/Parsers/ParserSelectWithUnionQuery.cpp:15: DB::ParserSelectWithUnionQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e13dc91 27. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 28. ./build_docker/./src/Parsers/ExpressionElementParsers.cpp:116: DB::ParserSubquery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003df8d885 29. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 30. ./build_docker/./src/Parsers/ParserUnionQueryElement.cpp:13: DB::ParserUnionQueryElement::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e1911fb 31. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:01:37.045244 [ 24864 ] {11a52478-f07d-4079-9f1f-74ad6243cb9b} executeQuery: Code: 306. DB::Exception: Maximum parse depth (1000) exceeded. Consider rising max_parser_depth parameter. (TOO_DEEP_RECURSION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:49378) (comment: 00984_parser_stack_overflow.sh) (in query: SELECT [[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned int&) @ 0x00000000183a6cca 4. ./src/Parsers/IParser.h:114: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e057d8c 5. ./build_docker/./src/Parsers/ExpressionElementParsers.cpp:980: DB::ParserNull::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003dfacc1d 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 7. ./build_docker/./src/Parsers/ExpressionElementParsers.cpp:1553: DB::ParserLiteral::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003dfb7e9e 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 9. ./build_docker/./src/Parsers/ExpressionElementParsers.cpp:1365: DB::ParserCollectionOfLiterals::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003dfdd4a7 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 11. ./src/Parsers/ExpressionElementParsers.h:343: DB::ParserArrayOfLiterals::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003b95d56d 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 13. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:2624: DB::ParserExpressionImpl::tryParseOperand(std::vector>, std::allocator>>>&, DB::IParser::Pos&, DB::Expected&) @ 0x000000003e0013ac 14. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:2465: DB::ParserExpressionImpl::parse(std::unique_ptr>, DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003dffd2b6 15. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:2331: DB::ParserExpression::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003dffbf96 16. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 17. ./build_docker/./src/Parsers/ExpressionElementParsers.cpp:2131: DB::ParserWithOptionalAlias::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003dfcc976 18. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 19. ./src/Parsers/ExpressionListParsers.h:216: DB::ParserExpressionWithOptionalAlias::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003dfea48e 20. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 21. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:53: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x000000003e00e92c 22. ./src/Parsers/ExpressionListParsers.h:40: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003dfee007 23. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 24. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:320: DB::ParserExpressionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003dff325e 25. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 26. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:325: DB::ParserNotEmptyExpressionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003dff36b2 27. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 28. ./build_docker/./src/Parsers/ParserSelectQuery.cpp:192: DB::ParserSelectQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e138af8 29. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 30. ./build_docker/./src/Parsers/ParserUnionQueryElement.cpp:13: DB::ParserUnionQueryElement::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e191284 31. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 2025.06.13 09:01:37.051393 [ 24864 ] {11a52478-f07d-4079-9f1f-74ad6243cb9b} DynamicQueryHandler: Code: 306. DB::Exception: Maximum parse depth (1000) exceeded. Consider rising max_parser_depth parameter. (TOO_DEEP_RECURSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned int&) @ 0x00000000183a6cca 4. ./src/Parsers/IParser.h:114: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e057d8c 5. ./build_docker/./src/Parsers/ExpressionElementParsers.cpp:980: DB::ParserNull::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003dfacc1d 6. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 7. ./build_docker/./src/Parsers/ExpressionElementParsers.cpp:1553: DB::ParserLiteral::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003dfb7e9e 8. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 9. ./build_docker/./src/Parsers/ExpressionElementParsers.cpp:1365: DB::ParserCollectionOfLiterals::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003dfdd4a7 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 11. ./src/Parsers/ExpressionElementParsers.h:343: DB::ParserArrayOfLiterals::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003b95d56d 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 13. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:2624: DB::ParserExpressionImpl::tryParseOperand(std::vector>, std::allocator>>>&, DB::IParser::Pos&, DB::Expected&) @ 0x000000003e0013ac 14. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:2465: DB::ParserExpressionImpl::parse(std::unique_ptr>, DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003dffd2b6 15. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:2331: DB::ParserExpression::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003dffbf96 16. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 17. ./build_docker/./src/Parsers/ExpressionElementParsers.cpp:2131: DB::ParserWithOptionalAlias::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003dfcc976 18. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 19. ./src/Parsers/ExpressionListParsers.h:216: DB::ParserExpressionWithOptionalAlias::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003dfea48e 20. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 21. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:53: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x000000003e00e92c 22. ./src/Parsers/ExpressionListParsers.h:40: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003dfee007 23. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 24. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:320: DB::ParserExpressionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003dff325e 25. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 26. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:325: DB::ParserNotEmptyExpressionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003dff36b2 27. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 28. ./build_docker/./src/Parsers/ParserSelectQuery.cpp:192: DB::ParserSelectQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e138af8 29. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b 30. ./build_docker/./src/Parsers/ParserUnionQueryElement.cpp:13: DB::ParserUnionQueryElement::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e191284 31. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e05767b (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:01:47.355846 [ 15867 ] {6f19d12a-8086-42ee-b538-672c11d8cc55} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Second doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Second(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43440) (comment: 01277_toUnixTimestamp64.sql) (query 1, line 1) (in query: -- Error cases SELECT toUnixTimestamp64Second();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 09:01:47.364879 [ 15867 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Second doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Second(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 09:01:47.399705 [ 15867 ] {848ccb52-676e-4c0f-b53c-0ed122d43978} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Milli(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43440) (comment: 01277_toUnixTimestamp64.sql) (query 2, line 3) (in query: SELECT toUnixTimestamp64Milli();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 09:01:47.406531 [ 15867 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Milli(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 09:01:47.444930 [ 15867 ] {d013fcb0-5bee-4da1-804d-68cb88123ab8} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Micro(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43440) (comment: 01277_toUnixTimestamp64.sql) (query 3, line 4) (in query: SELECT toUnixTimestamp64Micro();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 09:01:47.451831 [ 15867 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Micro(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 09:01:47.493225 [ 15867 ] {bda8f936-d876-4496-a111-c99e4b9166e1} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Nano(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43440) (comment: 01277_toUnixTimestamp64.sql) (query 4, line 5) (in query: SELECT toUnixTimestamp64Nano();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 09:01:47.501231 [ 15867 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Nano(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 09:01:47.796191 [ 15867 ] {8963bd0c-0ccc-4ae2-a8b6-417fddc22dd2} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'toUnixTimestamp64Second'. Expected: DateTime64, got: String: In scope SELECT toUnixTimestamp64Second('abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43440) (comment: 01277_toUnixTimestamp64.sql) (query 5, line 7) (in query: SELECT toUnixTimestamp64Second('abc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c037e87 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c0312c1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c02fb7f 6. DB::FunctionToUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001abf374d 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 09:01:47.804511 [ 15867 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'toUnixTimestamp64Second'. Expected: DateTime64, got: String: In scope SELECT toUnixTimestamp64Second('abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c037e87 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c0312c1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c02fb7f 6. DB::FunctionToUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001abf374d 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 09:01:47.848074 [ 15867 ] {d6d8a068-9beb-4732-87a2-f16b285981d6} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'toUnixTimestamp64Milli'. Expected: DateTime64, got: String: In scope SELECT toUnixTimestamp64Milli('abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43440) (comment: 01277_toUnixTimestamp64.sql) (query 6, line 8) (in query: SELECT toUnixTimestamp64Milli('abc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c037e87 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c0312c1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c02fb7f 6. DB::FunctionToUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001abf374d 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 09:01:47.855125 [ 15867 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'toUnixTimestamp64Milli'. Expected: DateTime64, got: String: In scope SELECT toUnixTimestamp64Milli('abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c037e87 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c0312c1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c02fb7f 6. DB::FunctionToUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001abf374d 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 09:01:47.891745 [ 15867 ] {2eced4b9-0f5b-4a27-b69e-84722fd16b26} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'toUnixTimestamp64Micro'. Expected: DateTime64, got: String: In scope SELECT toUnixTimestamp64Micro('abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43440) (comment: 01277_toUnixTimestamp64.sql) (query 7, line 9) (in query: SELECT toUnixTimestamp64Micro('abc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c037e87 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c0312c1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c02fb7f 6. DB::FunctionToUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001abf374d 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 09:01:47.900110 [ 15867 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'toUnixTimestamp64Micro'. Expected: DateTime64, got: String: In scope SELECT toUnixTimestamp64Micro('abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c037e87 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c0312c1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c02fb7f 6. DB::FunctionToUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001abf374d 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 09:01:47.936986 [ 15867 ] {e9500903-04d2-4415-aec8-4cc9524c46cc} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'toUnixTimestamp64Nano'. Expected: DateTime64, got: String: In scope SELECT toUnixTimestamp64Nano('abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43440) (comment: 01277_toUnixTimestamp64.sql) (query 8, line 10) (in query: SELECT toUnixTimestamp64Nano('abc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c037e87 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c0312c1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c02fb7f 6. DB::FunctionToUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001abf374d 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 09:01:47.937890 [ 15856 ] {2fe3990e-2ebc-4051-a83d-57c6b4968232} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 101.89 MiB (attempt to allocate chunk of 2.15 MiB bytes), maximum: 100.00 MiB.: while pushing to view test_9ks8xvqk.mv_01278_4 (2deccada-ab11-4437-a741-ec69ad237d6b). (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43396) (comment: 01278_min_insert_block_size_rows_for_materialized_views.sh) (query 1, line 2) (in query: insert into data_01278 select number, reinterpretAsString(number), // s1 reinterpretAsString(number), // s2 reinterpretAsString(number), // s3 reinterpretAsString(number), // s4 reinterpretAsString(number), // s5 reinterpretAsString(number), // s6 reinterpretAsString(number), // s7 reinterpretAsString(number) // s8 from numbers(200000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f53cbed 8. ./src/Common/PODArray.h:118: void DB::filterArraysImpl(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul> const&, long) @ 0x0000000038030a59 9. ./build_docker/./src/Columns/ColumnString.cpp:186: DB::ColumnString::filter(DB::PODArray, 63ul, 64ul> const&, long) const @ 0x00000000375d389a 10. ./build_docker/./src/Columns/ColumnNullable.cpp:334: DB::ColumnNullable::filter(DB::PODArray, 63ul, 64ul> const&, long) const @ 0x00000000374e5ada 11. ./build_docker/./src/Columns/FilterDescription.cpp:105: DB::FilterDescription::filter(DB::IColumn const&, long) const @ 0x000000003807354d 12. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:272: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000003ba1d143 13. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000003ba1a724 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 20. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:839: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000003bc8e70b 21. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e689 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 23. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d5ff 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 28. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 31. ? @ 0x00007f5206343ac3 2025.06.13 09:01:47.943617 [ 15867 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'toUnixTimestamp64Nano'. Expected: DateTime64, got: String: In scope SELECT toUnixTimestamp64Nano('abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c037e87 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c0312c1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c02fb7f 6. DB::FunctionToUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001abf374d 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 2025.06.13 09:01:47.984188 [ 15867 ] {6d663be2-9f43-417b-b64a-204609302ff0} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Second doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Second('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43440) (comment: 01277_toUnixTimestamp64.sql) (query 9, line 12) (in query: SELECT toUnixTimestamp64Second('abc', 123);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 09:01:47.992187 [ 15867 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Second doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Second('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 09:01:48.026509 [ 15867 ] {a7750fe7-1682-4549-bd0f-65abedb7ec27} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Milli('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43440) (comment: 01277_toUnixTimestamp64.sql) (query 10, line 13) (in query: SELECT toUnixTimestamp64Milli('abc', 123);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 09:01:48.032973 [ 15867 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Milli('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 09:01:48.039323 [ 15856 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 101.89 MiB (attempt to allocate chunk of 2.15 MiB bytes), maximum: 100.00 MiB.: while pushing to view test_9ks8xvqk.mv_01278_4 (2deccada-ab11-4437-a741-ec69ad237d6b). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f53cbed 8. ./src/Common/PODArray.h:118: void DB::filterArraysImpl(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul> const&, long) @ 0x0000000038030a59 9. ./build_docker/./src/Columns/ColumnString.cpp:186: DB::ColumnString::filter(DB::PODArray, 63ul, 64ul> const&, long) const @ 0x00000000375d389a 10. ./build_docker/./src/Columns/ColumnNullable.cpp:334: DB::ColumnNullable::filter(DB::PODArray, 63ul, 64ul> const&, long) const @ 0x00000000374e5ada 11. ./build_docker/./src/Columns/FilterDescription.cpp:105: DB::FilterDescription::filter(DB::IColumn const&, long) const @ 0x000000003807354d 12. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:272: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000003ba1d143 13. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000003ba1a724 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 20. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:839: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000003bc8e70b 21. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e689 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 23. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d5ff 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 28. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 31. ? @ 0x00007f5206343ac3 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:01:48.064918 [ 15867 ] {fb2c5ca4-952b-4056-9aad-270715b6b310} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Micro('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43440) (comment: 01277_toUnixTimestamp64.sql) (query 11, line 14) (in query: SELECT toUnixTimestamp64Micro('abc', 123);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 09:01:48.071299 [ 15867 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Micro('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 09:01:48.113931 [ 15867 ] {b8315fc2-348a-46b7-829d-873339ce79ca} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Nano('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43440) (comment: 01277_toUnixTimestamp64.sql) (query 12, line 15) (in query: SELECT toUnixTimestamp64Nano('abc', 123);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 09:01:48.122017 [ 15867 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Nano('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000028890777 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002bff7502 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff96b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 09:01:52.221751 [ 9234 ] {29518ca8-93d8-4a45-803a-2d9310d54f76} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 101.62 MiB (attempt to allocate chunk of 2.27 MiB bytes), maximum: 100.00 MiB.: while pushing to view test_9ks8xvqk.mv_01278_9 (d52273e5-dd5e-4cf8-8770-2158f202a167). (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43468) (comment: 01278_min_insert_block_size_rows_for_materialized_views.sh) (query 1, line 2) (in query: insert into data_01278 select number, reinterpretAsString(number), // s1 reinterpretAsString(number), // s2 reinterpretAsString(number), // s3 reinterpretAsString(number), // s4 reinterpretAsString(number), // s5 reinterpretAsString(number), // s6 reinterpretAsString(number), // s7 reinterpretAsString(number) // s8 from numbers(200000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f53d7c4 8. ./src/Common/PODArray.h:152: DB::ColumnVector::reserve(unsigned long) @ 0x0000000037a1a86e 9. DB::IColumn::prepareForSquashing(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&) @ 0x000000002bffccdf 10. ./build_docker/./src/Interpreters/Squashing.cpp:175: DB::Squashing::squash(std::vector>&&, DB::CollectionOfDerivedItems&&) @ 0x0000000032ff0593 11. ./build_docker/./src/Interpreters/Squashing.cpp:45: DB::Squashing::squash(DB::Chunk&&) @ 0x0000000032fee430 12. ./build_docker/./src/Processors/Transforms/SquashingTransform.cpp:36: DB::SquashingTransform::onFinish() @ 0x000000003bbc3f00 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e76f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 15. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d33c 16. ./build_docker/./src/Processors/Transforms/SquashingTransform.cpp:48: DB::SquashingTransform::work() @ 0x000000003bbc44dc 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 21. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 09:01:52.410982 [ 9234 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 101.62 MiB (attempt to allocate chunk of 2.27 MiB bytes), maximum: 100.00 MiB.: while pushing to view test_9ks8xvqk.mv_01278_9 (d52273e5-dd5e-4cf8-8770-2158f202a167). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f53d7c4 8. ./src/Common/PODArray.h:152: DB::ColumnVector::reserve(unsigned long) @ 0x0000000037a1a86e 9. DB::IColumn::prepareForSquashing(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&) @ 0x000000002bffccdf 10. ./build_docker/./src/Interpreters/Squashing.cpp:175: DB::Squashing::squash(std::vector>&&, DB::CollectionOfDerivedItems&&) @ 0x0000000032ff0593 11. ./build_docker/./src/Interpreters/Squashing.cpp:45: DB::Squashing::squash(DB::Chunk&&) @ 0x0000000032fee430 12. ./build_docker/./src/Processors/Transforms/SquashingTransform.cpp:36: DB::SquashingTransform::onFinish() @ 0x000000003bbc3f00 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e76f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 15. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d33c 16. ./build_docker/./src/Processors/Transforms/SquashingTransform.cpp:48: DB::SquashingTransform::work() @ 0x000000003bbc44dc 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 21. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:01:53.087059 [ 24843 ] {d0d41d2a-3103-4632-ab40-4eaf1b0802e8} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 8 ((): ([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([... Unmatched parentheses: ([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([. (SYNTAX_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:49394) (comment: 00984_parser_stack_overflow.sh) (in query: SELECT ([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008c167de 3. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003e1c5d8a 4. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003e1c5ed1 5. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033726084 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 7. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:01:53.092170 [ 24843 ] {d0d41d2a-3103-4632-ab40-4eaf1b0802e8} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 8 ((): ([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([... Unmatched parentheses: ([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008c167de 3. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003e1c5d8a 4. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003e1c5ed1 5. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033726084 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 7. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:01:55.083974 [ 24859 ] {467b9ab3-3118-44dd-8e60-1d5062c9805c} executeQuery: Code: 167. DB::Exception: AST is too deep. Maximum: 1000. (TOO_DEEP_AST) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:57790) (comment: 00984_parser_stack_overflow.sh) (in query: SELECT 1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000d04bc6a 4. ./build_docker/./src/Parsers/IAST.cpp:162: DB::IAST::checkDepthImpl(unsigned long) const @ 0x000000003e0525e1 5. ./src/Parsers/IAST.h:99: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x000000003e1c2cf2 6. ./build_docker/./src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003e1c5b90 7. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003e1c5ed1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033726084 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 10. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:01:55.089670 [ 24859 ] {467b9ab3-3118-44dd-8e60-1d5062c9805c} DynamicQueryHandler: Code: 167. DB::Exception: AST is too deep. Maximum: 1000. (TOO_DEEP_AST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000d04bc6a 4. ./build_docker/./src/Parsers/IAST.cpp:162: DB::IAST::checkDepthImpl(unsigned long) const @ 0x000000003e0525e1 5. ./src/Parsers/IAST.h:99: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x000000003e1c2cf2 6. ./build_docker/./src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003e1c5b90 7. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003e1c5ed1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033726084 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 10. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:02:09.395663 [ 405 ] {7d767517-63d1-413f-82fc-ab27dffbb7f2} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 17 (0.0120599): 0.0120599. Expected one of: token sequence, Dot, token, OR, AND, IS NOT DISTINCT FROM, IS NULL, IS NOT NULL, BETWEEN, NOT BETWEEN, LIKE, ILIKE, NOT LIKE, NOT ILIKE, REGEXP, IN, NOT IN, GLOBAL IN, GLOBAL NOT IN, MOD, DIV, alias, AS, identifier, Comma, FROM, PREWHERE, WHERE, GROUP BY, WITH, HAVING, WINDOW, QUALIFY, ORDER BY, LIMIT, OFFSET, FETCH, SETTINGS, UNION, EXCEPT, INTERSECT, INTO OUTFILE, FORMAT, ParallelWithClause, PARALLEL WITH, end of query. (SYNTAX_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:41354) (comment: 02833_concurrent_sessions.sh) (in query: SELECT 5, sleep 0.0120599), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008c167de 3. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003e1c5d8a 4. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003e1c5ed1 5. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033726084 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 7. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:02:09.400945 [ 405 ] {7d767517-63d1-413f-82fc-ab27dffbb7f2} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 17 (0.0120599): 0.0120599. Expected one of: token sequence, Dot, token, OR, AND, IS NOT DISTINCT FROM, IS NULL, IS NOT NULL, BETWEEN, NOT BETWEEN, LIKE, ILIKE, NOT LIKE, NOT ILIKE, REGEXP, IN, NOT IN, GLOBAL IN, GLOBAL NOT IN, MOD, DIV, alias, AS, identifier, Comma, FROM, PREWHERE, WHERE, GROUP BY, WITH, HAVING, WINDOW, QUALIFY, ORDER BY, LIMIT, OFFSET, FETCH, SETTINGS, UNION, EXCEPT, INTERSECT, INTO OUTFILE, FORMAT, ParallelWithClause, PARALLEL WITH, end of query. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008c167de 3. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003e1c5d8a 4. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003e1c5ed1 5. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033726084 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 7. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:02:09.692900 [ 24872 ] {} DynamicQueryHandler: Code: 516. DB::Exception: 02833_HTTP_USER_41559: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e1a87c5 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032eff051 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000003ae3ec8a 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000003abbe013 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abbf02e 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:02:09.693957 [ 9237 ] {} DynamicQueryHandler: Code: 516. DB::Exception: 02833_HTTP_WITH_SESSION_ID_USER_41559: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e1a87c5 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032eff051 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000003ae3ec8a 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000003abbe013 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abbf02e 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:02:09.730298 [ 24844 ] {61247c37-1175-4b09-9276-e7b21eecdad4} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 17 (0.01868): 0.01868. Expected one of: token sequence, Dot, token, OR, AND, IS NOT DISTINCT FROM, IS NULL, IS NOT NULL, BETWEEN, NOT BETWEEN, LIKE, ILIKE, NOT LIKE, NOT ILIKE, REGEXP, IN, NOT IN, GLOBAL IN, GLOBAL NOT IN, MOD, DIV, alias, AS, identifier, Comma, FROM, PREWHERE, WHERE, GROUP BY, WITH, HAVING, WINDOW, QUALIFY, ORDER BY, LIMIT, OFFSET, FETCH, SETTINGS, UNION, EXCEPT, INTERSECT, INTO OUTFILE, FORMAT, ParallelWithClause, PARALLEL WITH, end of query. (SYNTAX_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:41388) (comment: 02833_concurrent_sessions.sh) (in query: SELECT 5, sleep 0.01868), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008c167de 3. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003e1c5d8a 4. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003e1c5ed1 5. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033726084 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 7. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:02:09.735407 [ 24844 ] {61247c37-1175-4b09-9276-e7b21eecdad4} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 17 (0.01868): 0.01868. Expected one of: token sequence, Dot, token, OR, AND, IS NOT DISTINCT FROM, IS NULL, IS NOT NULL, BETWEEN, NOT BETWEEN, LIKE, ILIKE, NOT LIKE, NOT ILIKE, REGEXP, IN, NOT IN, GLOBAL IN, GLOBAL NOT IN, MOD, DIV, alias, AS, identifier, Comma, FROM, PREWHERE, WHERE, GROUP BY, WITH, HAVING, WINDOW, QUALIFY, ORDER BY, LIMIT, OFFSET, FETCH, SETTINGS, UNION, EXCEPT, INTERSECT, INTO OUTFILE, FORMAT, ParallelWithClause, PARALLEL WITH, end of query. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008c167de 3. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003e1c5d8a 4. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003e1c5ed1 5. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033726084 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 7. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:02:09.755837 [ 24844 ] {} DynamicQueryHandler: Code: 516. DB::Exception: 02833_HTTP_WITH_SESSION_ID_USER_41559: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e1a87c5 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032eff051 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000003ae3ec8a 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000003abbe013 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abbf02e 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:02:09.788706 [ 24844 ] {a7878cb0-3f85-4fdb-9f44-c936c46cf900} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 17 (0.0129427): 0.0129427. Expected one of: token sequence, Dot, token, OR, AND, IS NOT DISTINCT FROM, IS NULL, IS NOT NULL, BETWEEN, NOT BETWEEN, LIKE, ILIKE, NOT LIKE, NOT ILIKE, REGEXP, IN, NOT IN, GLOBAL IN, GLOBAL NOT IN, MOD, DIV, alias, AS, identifier, Comma, FROM, PREWHERE, WHERE, GROUP BY, WITH, HAVING, WINDOW, QUALIFY, ORDER BY, LIMIT, OFFSET, FETCH, SETTINGS, UNION, EXCEPT, INTERSECT, INTO OUTFILE, FORMAT, ParallelWithClause, PARALLEL WITH, end of query. (SYNTAX_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:41410) (comment: 02833_concurrent_sessions.sh) (in query: SELECT 5, sleep 0.0129427), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008c167de 3. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003e1c5d8a 4. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003e1c5ed1 5. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033726084 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 7. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:02:09.793940 [ 24844 ] {a7878cb0-3f85-4fdb-9f44-c936c46cf900} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 17 (0.0129427): 0.0129427. Expected one of: token sequence, Dot, token, OR, AND, IS NOT DISTINCT FROM, IS NULL, IS NOT NULL, BETWEEN, NOT BETWEEN, LIKE, ILIKE, NOT LIKE, NOT ILIKE, REGEXP, IN, NOT IN, GLOBAL IN, GLOBAL NOT IN, MOD, DIV, alias, AS, identifier, Comma, FROM, PREWHERE, WHERE, GROUP BY, WITH, HAVING, WINDOW, QUALIFY, ORDER BY, LIMIT, OFFSET, FETCH, SETTINGS, UNION, EXCEPT, INTERSECT, INTO OUTFILE, FORMAT, ParallelWithClause, PARALLEL WITH, end of query. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008c167de 3. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003e1c5d8a 4. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003e1c5ed1 5. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033726084 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003374112e 7. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abc9950 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:02:09.833006 [ 24844 ] {} DynamicQueryHandler: Code: 516. DB::Exception: 02833_HTTP_USER_41559: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e1a87c5 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032eff051 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000003ae3ec8a 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000003abbe013 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abbf02e 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:02:09.839628 [ 15837 ] {} DynamicQueryHandler: Code: 516. DB::Exception: 02833_HTTP_WITH_SESSION_ID_USER_41559: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e1a87c5 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032eff051 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000003ae3ec8a 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000003abbe013 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abbf02e 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:02:09.973306 [ 405 ] {} DynamicQueryHandler: Code: 516. DB::Exception: 02833_HTTP_USER_41559: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e1a87c5 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032eff051 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000003ae3ec8a 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000003abbe013 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003abbf02e 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003abd51c1 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:02:11.135023 [ 2085 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: 02833_TCP_USER_41559_2: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e1a87c5 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032eff051 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032efdcac 6. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x000000003ada9cb3 7. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x000000003ad8af5f 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:02:11.136053 [ 2085 ] {} ServerErrorHandler: Code: 516. DB::Exception: 02833_TCP_USER_41559_2: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e1a87c5 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032eff051 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032efdcac 6. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x000000003ada9cb3 7. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x000000003ad8af5f 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:02:11.137194 [ 15838 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: 02833_TCP_USER_41559_1: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e1a87c5 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032eff051 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032efdcac 6. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x000000003ada9cb3 7. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x000000003ad8af5f 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:02:11.137760 [ 15838 ] {} ServerErrorHandler: Code: 516. DB::Exception: 02833_TCP_USER_41559_1: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e1a87c5 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032eff051 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032efdcac 6. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x000000003ada9cb3 7. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x000000003ad8af5f 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:02:11.632990 [ 2134 ] {} MySQLHandler: Authentication for user 02833_MYSQL_USER_41559 failed. 2025.06.13 09:02:11.634034 [ 2134 ] {} MySQLHandler: DB::Exception: 02833_MYSQL_USER_41559: Authentication failed: password is incorrect, or there is no user with such name. 2025.06.13 09:02:11.637249 [ 15871 ] {f3a6697e-47f7-4b40-a9e8-76ffa0d2c421} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user 02833_MYSQL_USER_41559): mysqlxx::ConnectionFailed 2025.06.13 09:02:11.638683 [ 15871 ] {f3a6697e-47f7-4b40-a9e8-76ffa0d2c421} Application: Connection to system@127.0.0.1:9004 as user 02833_MYSQL_USER_41559 failed: mysqlxx::ConnectionFailed: 02833_MYSQL_USER_41559: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004) 2025.06.13 09:02:11.639596 [ 15871 ] {f3a6697e-47f7-4b40-a9e8-76ffa0d2c421} Application: Connection to mysql failed 1 times 2025.06.13 09:02:11.896070 [ 15871 ] {f3a6697e-47f7-4b40-a9e8-76ffa0d2c421} executeQuery: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user 02833_MYSQL_USER_41559, ERROR 516 : mysqlxx::ConnectionFailed: 02833_MYSQL_USER_41559: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48498) (comment: 02833_concurrent_sessions.sh) (query 1, line 1) (in query: SELECT 1 FROM mysql('127.0.0.1:9004', 'system', 'one', '02833_MYSQL_USER_41559', '[HIDDEN]', SETTINGS connection_max_tries = 1)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x00000000411788d4 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000002fd1adde 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x0000000038766a3f 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x00000000387657d5 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x00000000266ac660 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000266aa67a 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d0326ad 11. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316edd5f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030336f50 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 09:02:11.907709 [ 15871 ] {} TCPHandler: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user 02833_MYSQL_USER_41559, ERROR 516 : mysqlxx::ConnectionFailed: 02833_MYSQL_USER_41559: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x00000000411788d4 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000002fd1adde 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x0000000038766a3f 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x00000000387657d5 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x00000000266ac660 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000266aa67a 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d0326ad 11. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316edd5f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030336f50 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 09:02:12.766590 [ 9234 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: 02833_TCP_USER_41559_1: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e1a87c5 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032eff051 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032efdcac 6. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x000000003ada9cb3 7. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x000000003ad8af5f 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:02:12.767327 [ 9234 ] {} ServerErrorHandler: Code: 516. DB::Exception: 02833_TCP_USER_41559_1: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e1a87c5 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032eff051 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032efdcac 6. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x000000003ada9cb3 7. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x000000003ad8af5f 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:02:12.804363 [ 9234 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: 02833_TCP_USER_41559_2: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e1a87c5 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032eff051 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032efdcac 6. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x000000003ada9cb3 7. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x000000003ad8af5f 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:02:12.805092 [ 9234 ] {} ServerErrorHandler: Code: 516. DB::Exception: 02833_TCP_USER_41559_2: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e1a87c5 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032eff051 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032efdcac 6. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x000000003ada9cb3 7. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x000000003ad8af5f 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:02:13.957775 [ 2134 ] {} MySQLHandler: Authentication for user 02833_MYSQL_USER_41559 failed. 2025.06.13 09:02:13.957957 [ 2134 ] {} MySQLHandler: DB::Exception: 02833_MYSQL_USER_41559: Authentication failed: password is incorrect, or there is no user with such name. 2025.06.13 09:02:13.958940 [ 24859 ] {b8d631f6-39fc-4e7f-9483-551d9240387d} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user 02833_MYSQL_USER_41559): mysqlxx::ConnectionFailed 2025.06.13 09:02:13.959186 [ 24859 ] {b8d631f6-39fc-4e7f-9483-551d9240387d} Application: Connection to system@127.0.0.1:9004 as user 02833_MYSQL_USER_41559 failed: mysqlxx::ConnectionFailed: 02833_MYSQL_USER_41559: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004) 2025.06.13 09:02:13.959324 [ 24859 ] {b8d631f6-39fc-4e7f-9483-551d9240387d} Application: Connection to mysql failed 1 times 2025.06.13 09:02:13.967885 [ 24859 ] {b8d631f6-39fc-4e7f-9483-551d9240387d} executeQuery: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user 02833_MYSQL_USER_41559, ERROR 516 : mysqlxx::ConnectionFailed: 02833_MYSQL_USER_41559: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42790) (comment: 02833_concurrent_sessions.sh) (query 1, line 1) (in query: SELECT 1 FROM mysql('127.0.0.1:9004', 'system', 'one', '02833_MYSQL_USER_41559', '[HIDDEN]', SETTINGS connection_max_tries = 1)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x00000000411788d4 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000002fd1adde 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x0000000038766a3f 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x00000000387657d5 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x00000000266ac660 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000266aa67a 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d0326ad 11. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316edd5f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030336f50 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 09:02:14.010498 [ 24859 ] {} TCPHandler: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user 02833_MYSQL_USER_41559, ERROR 516 : mysqlxx::ConnectionFailed: 02833_MYSQL_USER_41559: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x00000000411788d4 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000002fd1adde 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x0000000038766a3f 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x00000000387657d5 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x00000000266ac660 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000266aa67a 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d0326ad 11. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316edd5f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030336f50 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 09:02:14.288701 [ 24843 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: 02833_TCP_USER_41559_1: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e1a87c5 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032eff051 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032efdcac 6. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x000000003ada9cb3 7. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x000000003ad8af5f 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:02:14.289416 [ 24843 ] {} ServerErrorHandler: Code: 516. DB::Exception: 02833_TCP_USER_41559_1: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e1a87c5 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032eff051 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032efdcac 6. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x000000003ada9cb3 7. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x000000003ad8af5f 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:02:14.401629 [ 404 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: 02833_TCP_USER_41559_2: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e1a87c5 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032eff051 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032efdcac 6. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x000000003ada9cb3 7. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x000000003ad8af5f 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:02:14.402330 [ 404 ] {} ServerErrorHandler: Code: 516. DB::Exception: 02833_TCP_USER_41559_2: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e1a87c5 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032eff051 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032efdcac 6. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x000000003ada9cb3 7. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x000000003ad8af5f 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:02:16.048993 [ 2134 ] {} MySQLHandler: Authentication for user 02833_MYSQL_USER_41559 failed. 2025.06.13 09:02:16.049131 [ 2134 ] {} MySQLHandler: DB::Exception: 02833_MYSQL_USER_41559: Authentication failed: password is incorrect, or there is no user with such name. 2025.06.13 09:02:16.050155 [ 24843 ] {800fc5d7-8c95-4a7e-b5b2-8a296f15476f} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user 02833_MYSQL_USER_41559): mysqlxx::ConnectionFailed 2025.06.13 09:02:16.050486 [ 24843 ] {800fc5d7-8c95-4a7e-b5b2-8a296f15476f} Application: Connection to system@127.0.0.1:9004 as user 02833_MYSQL_USER_41559 failed: mysqlxx::ConnectionFailed: 02833_MYSQL_USER_41559: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004) 2025.06.13 09:02:16.050613 [ 24843 ] {800fc5d7-8c95-4a7e-b5b2-8a296f15476f} Application: Connection to mysql failed 1 times 2025.06.13 09:02:16.058136 [ 24843 ] {800fc5d7-8c95-4a7e-b5b2-8a296f15476f} executeQuery: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user 02833_MYSQL_USER_41559, ERROR 516 : mysqlxx::ConnectionFailed: 02833_MYSQL_USER_41559: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42852) (comment: 02833_concurrent_sessions.sh) (query 1, line 1) (in query: SELECT 1 FROM mysql('127.0.0.1:9004', 'system', 'one', '02833_MYSQL_USER_41559', '[HIDDEN]', SETTINGS connection_max_tries = 1)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x00000000411788d4 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000002fd1adde 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x0000000038766a3f 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x00000000387657d5 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x00000000266ac660 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000266aa67a 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d0326ad 11. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316edd5f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030336f50 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 09:02:16.071189 [ 24843 ] {} TCPHandler: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user 02833_MYSQL_USER_41559, ERROR 516 : mysqlxx::ConnectionFailed: 02833_MYSQL_USER_41559: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x00000000411788d4 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000002fd1adde 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x0000000038766a3f 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x00000000387657d5 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x00000000266ac660 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000266aa67a 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d0326ad 11. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316edd5f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030336f50 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 09:02:16.344664 [ 37782 ] {4305cb90-752f-4364-b5b1-a861ae7a51bd} StorageMaterializedView: Inner table does not exist, will not backup any data 2025.06.13 09:02:17.783321 [ 9261 ] {88b26f45-c906-4810-8cd8-924bb670572d} executeQuery: Code: 46. DB::Exception: Function with name `plu` does not exist. In scope SELECT plu(1, 1) SETTINGS enable_analyzer = 1. Maybe you meant: ['plus']. (UNKNOWN_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42920) (comment: 02477_analyzer_function_hints.sh) (query 1, line 1) (in query: SELECT plu(1, 1) SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3350: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003038f5f5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 09:02:17.796537 [ 9261 ] {} TCPHandler: Code: 46. DB::Exception: Function with name `plu` does not exist. In scope SELECT plu(1, 1) SETTINGS enable_analyzer = 1. Maybe you meant: ['plus']. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3350: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003038f5f5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 09:02:18.705515 [ 24859 ] {69cba81f-9eae-4bcc-9408-5f87d673fcb9} executeQuery: Code: 46. DB::Exception: Function with name `uniqExac` does not exist. In scope SELECT uniqExac(1, 1) SETTINGS enable_analyzer = 1. Maybe you meant: ['uniqExact']. (UNKNOWN_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42938) (comment: 02477_analyzer_function_hints.sh) (query 1, line 1) (in query: SELECT uniqExac(1, 1) SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3350: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003038f5f5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 09:02:18.716768 [ 24859 ] {} TCPHandler: Code: 46. DB::Exception: Function with name `uniqExac` does not exist. In scope SELECT uniqExac(1, 1) SETTINGS enable_analyzer = 1. Maybe you meant: ['uniqExact']. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3350: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003038f5f5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 09:02:21.227104 [ 24859 ] {2ee11031-76ee-40e2-8c09-8ac79a4b3734} executeQuery: Code: 46. DB::Exception: Function with name `test_user_defined_function_test_3je4nprnA` does not exist. In scope SELECT test_user_defined_function_test_3je4nprnA(1) SETTINGS enable_analyzer = 1. Maybe you meant: ['test_user_defined_function_test_3je4nprn']. (UNKNOWN_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43024) (comment: 02477_analyzer_function_hints.sh) (query 1, line 1) (in query: SELECT test_user_defined_function_test_3je4nprnA(1) SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3350: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003038f5f5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 09:02:21.242939 [ 24859 ] {} TCPHandler: Code: 46. DB::Exception: Function with name `test_user_defined_function_test_3je4nprnA` does not exist. In scope SELECT test_user_defined_function_test_3je4nprnA(1) SETTINGS enable_analyzer = 1. Maybe you meant: ['test_user_defined_function_test_3je4nprn']. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3350: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003038f5f5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 09:02:22.898729 [ 2136 ] {1e2edf42-6d9c-4393-9d51-4e994b6e5f97} executeQuery: Code: 46. DB::Exception: Function with name `lambda_functio` does not exist. In scope WITH x -> (x + 1) AS lambda_function SELECT lambda_functio(1) SETTINGS enable_analyzer = 1. Maybe you meant: ['lambda_function']. (UNKNOWN_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43134) (comment: 02477_analyzer_function_hints.sh) (query 1, line 1) (in query: WITH (x -> x + 1) AS lambda_function SELECT lambda_functio(1) SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3350: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003038f5f5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 09:02:22.909404 [ 2136 ] {} TCPHandler: Code: 46. DB::Exception: Function with name `lambda_functio` does not exist. In scope WITH x -> (x + 1) AS lambda_function SELECT lambda_functio(1) SETTINGS enable_analyzer = 1. Maybe you meant: ['lambda_function']. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3350: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003038f5f5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 09:02:23.791610 [ 24858 ] {acb0ef5a-3a3e-46a5-826b-e1ecbaa459b5} executeQuery: Code: 63. DB::Exception: Aggregate function with name 'row_numbe' does not exist. In scope SELECT row_numbe() OVER (PARTITION BY 1) SETTINGS enable_analyzer = 1. Maybe you meant: ['row_number']. (UNKNOWN_AGGREGATE_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38624) (comment: 02477_analyzer_function_hints.sh) (query 1, line 1) (in query: SELECT row_numbe() OVER (PARTITION BY 1) SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x0000000027757917 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3270: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003038c54c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 09:02:23.802650 [ 24858 ] {} TCPHandler: Code: 63. DB::Exception: Aggregate function with name 'row_numbe' does not exist. In scope SELECT row_numbe() OVER (PARTITION BY 1) SETTINGS enable_analyzer = 1. Maybe you meant: ['row_number']. (UNKNOWN_AGGREGATE_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x0000000027757917 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3270: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003038c54c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 09:02:25.463829 [ 24841 ] {961c4370-1323-45f6-8d77-82df630cd116} executeQuery: Code: 182. DB::Exception: Table expression test_mfrg598q.m AS __table1 does not support column __table1.f in PREWHERE. In query SELECT * FROM m PREWHERE f = 0. (ILLEGAL_PREWHERE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38640) (comment: 02575_merge_prewhere_different_default_kind.sql) (query 8, line 29) (in query: SELECT * FROM m PREWHERE f = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000031078af2 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003107853b 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003107853b 7. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x000000003106fdb2 8. ./build_docker/./src/Planner/Planner.cpp:1501: DB::Planner::buildPlanForQueryNode() @ 0x0000000032af81bf 9. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 09:02:25.472054 [ 24841 ] {} TCPHandler: Code: 182. DB::Exception: Table expression test_mfrg598q.m AS __table1 does not support column __table1.f in PREWHERE. In query SELECT * FROM m PREWHERE f = 0. (ILLEGAL_PREWHERE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000031078af2 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003107853b 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003107853b 7. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x000000003106fdb2 8. ./build_docker/./src/Planner/Planner.cpp:1501: DB::Planner::buildPlanForQueryNode() @ 0x0000000032af81bf 9. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 09:02:33.843569 [ 24844 ] {8032b3b4-615d-4a12-9d27-37fede9b8b95} executeQuery: Code: 182. DB::Exception: Table expression merge(currentDatabase(), '^data$') does not support column __table1._table in PREWHERE. In query SELECT 1 FROM merge(currentDatabase(), '^data$') PREWHERE _table IN (NULL). (ILLEGAL_PREWHERE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38364) (comment: 01931_storage_merge_no_columns.sql) (query 3, line 3) (in query: select 1 from merge(currentDatabase(), '^data$') prewhere _table in (NULL);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000031078af2 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003107853b 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003107853b 7. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x000000003106fdb2 8. ./build_docker/./src/Planner/Planner.cpp:1501: DB::Planner::buildPlanForQueryNode() @ 0x0000000032af81bf 9. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 09:02:33.852386 [ 24844 ] {} TCPHandler: Code: 182. DB::Exception: Table expression merge(currentDatabase(), '^data$') does not support column __table1._table in PREWHERE. In query SELECT 1 FROM merge(currentDatabase(), '^data$') PREWHERE _table IN (NULL). (ILLEGAL_PREWHERE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008dca217 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000031078af2 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003107853b 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003107853b 7. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x000000003106fdb2 8. ./build_docker/./src/Planner/Planner.cpp:1501: DB::Planner::buildPlanForQueryNode() @ 0x0000000032af81bf 9. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 09:02:37.409189 [ 2138 ] {633a483c-f030-4784-975d-5ab8cd4339bf} executeQuery: Code: 36. DB::Exception: Compression codec GCD does not compress anything. You may want to add generic compression algorithm after other transformations, like: GCD, LZ4. (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38440) (comment: 02872_gcd_codec.sql) (query 1, line 1) (in query: -- GCD codec can't be used stand-alone CREATE TEMPORARY TABLE table_gcd_codec (n UInt64 CODEC(GCD)) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001a317bad 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:207: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003dd497d8 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000328d07cd 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000328d60b9 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000328fff5d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:02:37.416791 [ 2138 ] {} TCPHandler: Code: 36. DB::Exception: Compression codec GCD does not compress anything. You may want to add generic compression algorithm after other transformations, like: GCD, LZ4. (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001a317bad 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:207: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003dd497d8 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000328d07cd 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000328d60b9 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000328fff5d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:02:37.640643 [ 2138 ] {82d23443-815f-42e8-b34f-41968840d0b4} executeQuery: Code: 36. DB::Exception: Codec GCD cannot be applied to column String because it can only be used with Int*, UInt*, Decimal*, Date* or DateTime* types. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38440) (comment: 02872_gcd_codec.sql) (query 2, line 4) (in query: -- GCD codec rejects non-integer/decimal/datetime types CREATE TEMPORARY TABLE table_gcd_codec (str String CODEC(GCD, LZ4)) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Compression/CompressionCodecGCD.cpp:255: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl[abi:ne190107] (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x000000003dd42cfc 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003dc24a68 6. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000003dd4aff2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f4dc59d 8. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f4dcf01 9. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003dd4693f 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000328d07cd 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000328d60b9 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000328fff5d 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 09:02:37.647658 [ 2138 ] {} TCPHandler: Code: 36. DB::Exception: Codec GCD cannot be applied to column String because it can only be used with Int*, UInt*, Decimal*, Date* or DateTime* types. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Compression/CompressionCodecGCD.cpp:255: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl[abi:ne190107] (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x000000003dd42cfc 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003dc24a68 6. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000003dd4aff2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f4dc59d 8. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f4dcf01 9. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003dd4693f 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000328d07cd 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000328d60b9 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000328fff5d 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 09:03:38.092291 [ 2085 ] {9ebb62f7-1ffb-4f04-bc75-ac62b8a218da} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `c1` in scope SELECT 0 AS c0, c0 AS c1, toInt32((c1 AS c0) % 2 AS c1) AS c2. Maybe you meant: ['c1']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39538) (comment: 03334_aliases_function_infinite_loop.sql) (query 5, line 7) (in query: CREATE VIEW v0 AS (SELECT 0 AS c0, c0 AS c1, f0(c1) AS c2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000303dd3a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032b465 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae4366 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:957: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000328de04c 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000328fff5d 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 09:03:38.099477 [ 2085 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `c1` in scope SELECT 0 AS c0, c0 AS c1, toInt32((c1 AS c0) % 2 AS c1) AS c2. Maybe you meant: ['c1']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000303dd3a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032b465 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030375732 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae4366 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:957: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000328de04c 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000328fff5d 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 2025.06.13 09:03:40.136111 [ 2085 ] {bfe51b80-7cf2-4ea7-9b8f-99df133e87f9} executeQuery: Code: 81. DB::Exception: Database test_03333 does not exist. (UNKNOWN_DATABASE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39540) (comment: 03333_merge_table_total_rows_no_database_system_tables_exception.sql) (query 9, line 12) (in query: SELECT * FROM merge;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Storages/StorageMerge.cpp:1382: DB::StorageMerge::DatabaseNameOrRegexp::getDatabaseIterator(String const&, std::shared_ptr) const @ 0x00000000386e516f 6. ./build_docker/./src/Storages/StorageMerge.cpp:1415: DB::StorageMerge::DatabaseNameOrRegexp::getDatabaseIterators(std::shared_ptr) const @ 0x0000000038697556 7. ./build_docker/./src/Storages/StorageMerge.cpp:268: DB::StorageMerge::getStorageSnapshot(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000386a5658 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:196: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x00000000310240b8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035d64c 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4364: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c4340 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 29. ? @ 0x00007f5206343ac3 30. ? @ 0x00007f52063d5850 2025.06.13 09:03:40.143250 [ 2085 ] {} TCPHandler: Code: 81. DB::Exception: Database test_03333 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Storages/StorageMerge.cpp:1382: DB::StorageMerge::DatabaseNameOrRegexp::getDatabaseIterator(String const&, std::shared_ptr) const @ 0x00000000386e516f 6. ./build_docker/./src/Storages/StorageMerge.cpp:1415: DB::StorageMerge::DatabaseNameOrRegexp::getDatabaseIterators(std::shared_ptr) const @ 0x0000000038697556 7. ./build_docker/./src/Storages/StorageMerge.cpp:268: DB::StorageMerge::getStorageSnapshot(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000386a5658 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:196: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x00000000310240b8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035d64c 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4364: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c4340 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 29. ? @ 0x00007f5206343ac3 30. ? @ 0x00007f52063d5850 2025.06.13 09:03:40.441622 [ 34536 ] {278e8083-2571-44cf-9f37-a81b4e857ec2} StorageSystemTables: Code: 81. DB::Exception: Database test_03333 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Storages/StorageMerge.cpp:1382: DB::StorageMerge::DatabaseNameOrRegexp::getDatabaseIterator(String const&, std::shared_ptr) const @ 0x00000000386e516f 6. ./build_docker/./src/Storages/StorageMerge.cpp:1415: DB::StorageMerge::DatabaseNameOrRegexp::getDatabaseIterators(std::shared_ptr) const @ 0x0000000038697556 7. ./build_docker/./src/Storages/StorageMerge.cpp:268: DB::StorageMerge::totalRows(std::shared_ptr) const @ 0x00000000386ec1fc 8. ./build_docker/./src/Storages/System/StorageSystemTables.cpp:599: DB::TablesBlockSource::generate() @ 0x00000000269d3501 9. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 10. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 15. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:03:40.558950 [ 34536 ] {278e8083-2571-44cf-9f37-a81b4e857ec2} StorageSystemTables: Code: 81. DB::Exception: Database test_03333 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Storages/StorageMerge.cpp:1382: DB::StorageMerge::DatabaseNameOrRegexp::getDatabaseIterator(String const&, std::shared_ptr) const @ 0x00000000386e516f 6. ./build_docker/./src/Storages/StorageMerge.cpp:1415: DB::StorageMerge::DatabaseNameOrRegexp::getDatabaseIterators(std::shared_ptr) const @ 0x0000000038697556 7. ./build_docker/./src/Storages/StorageMerge.cpp:268: DB::StorageMerge::totalBytes(std::shared_ptr) const @ 0x00000000386ecedc 8. ./build_docker/./src/Storages/System/StorageSystemTables.cpp:617: DB::TablesBlockSource::generate() @ 0x00000000269d3822 9. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 10. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 15. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:03:51.959078 [ 2085 ] {0c1cab0c-6b7a-49d5-a99e-66ba3cfc4272} test_v36ilgiv.test_table (3b783d94-1387-4c51-a171-a715855741d9): Failed to alter table in database, reverting changes 2025.06.13 09:03:52.179520 [ 2085 ] {0c1cab0c-6b7a-49d5-a99e-66ba3cfc4272} executeQuery: Code: 179. DB::Exception: Different expressions with the same alias input_column_name: metadata_b AS input_column_name and metadata_a AS input_column_name : While processing metadata_b AS input_column_name: default expression and column type are incompatible. (MULTIPLE_EXPRESSIONS_FOR_ALIAS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57208) (comment: 03274_aliases_in_udf.sql) (query 8, line 25) (in query: ALTER TABLE test_table ADD COLUMN mat_b String MATERIALIZED 03274_test_function(metadata_b);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Interpreters/QueryAliasesVisitor.cpp:124: DB::QueryAliasesMatcher::visitOther(std::shared_ptr const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000032eb7360 4. ./build_docker/./src/Interpreters/QueryAliasesVisitor.cpp:54: DB::QueryAliasesMatcher::visit(std::shared_ptr const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000032eb4203 5. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor, false, false, std::shared_ptr const>::doVisit(std::shared_ptr const&) @ 0x0000000032ebacf5 6. ./src/Interpreters/InDepthNodeVisitor.h:61: void DB::InDepthNodeVisitor, false, false, std::shared_ptr const>::visitChildren(std::shared_ptr const&) @ 0x0000000032ebb1ef 7. ./src/Interpreters/InDepthNodeVisitor.h:59: void DB::InDepthNodeVisitor, false, false, std::shared_ptr const>::visitChildren(std::shared_ptr const&) @ 0x0000000032ebb1e4 8. ./src/Interpreters/InDepthNodeVisitor.h:59: void DB::InDepthNodeVisitor, false, false, std::shared_ptr const>::visitChildren(std::shared_ptr const&) @ 0x0000000032ebb1e4 9. ./src/Interpreters/InDepthNodeVisitor.h:59: void DB::InDepthNodeVisitor, false, false, std::shared_ptr const>::visitChildren(std::shared_ptr const&) @ 0x0000000032ebb1e4 10. ./src/Interpreters/InDepthNodeVisitor.h:59: void DB::InDepthNodeVisitor, false, false, std::shared_ptr const>::visitChildren(std::shared_ptr const&) @ 0x0000000032ebb1e4 11. ./src/Interpreters/InDepthNodeVisitor.h:59: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x000000003351f9c2 12. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1527: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000335251ec 13. ./build_docker/./src/Storages/ColumnsDescription.cpp:1017: DB::(anonymous namespace)::validateColumnsDefaultsAndGetSampleBlockImpl(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr, bool) @ 0x00000000381e3e3f 14. ./build_docker/./src/Storages/ColumnsDescription.cpp:1044: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000381e5633 15. ./build_docker/./src/Databases/DatabasesCommon.cpp:91: DB::applyMetadataChangesToCreateQuery(std::shared_ptr const&, DB::StorageInMemoryMetadata const&, std::shared_ptr) @ 0x000000002f9c92d3 16. ./build_docker/./src/Databases/DatabaseOrdinary.cpp:611: DB::DatabaseOrdinary::alterTable(std::shared_ptr, DB::StorageID const&, DB::StorageInMemoryMetadata const&) @ 0x000000002f8b9bfc 17. ./build_docker/./src/Storages/StorageMergeTree.cpp:441: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003a39e125 18. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 19. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 29. ? @ 0x00007f5206343ac3 30. ? @ 0x00007f52063d5850 2025.06.13 09:03:52.187428 [ 2085 ] {} TCPHandler: Code: 179. DB::Exception: Different expressions with the same alias input_column_name: metadata_b AS input_column_name and metadata_a AS input_column_name : While processing metadata_b AS input_column_name: default expression and column type are incompatible. (MULTIPLE_EXPRESSIONS_FOR_ALIAS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Interpreters/QueryAliasesVisitor.cpp:124: DB::QueryAliasesMatcher::visitOther(std::shared_ptr const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000032eb7360 4. ./build_docker/./src/Interpreters/QueryAliasesVisitor.cpp:54: DB::QueryAliasesMatcher::visit(std::shared_ptr const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000032eb4203 5. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor, false, false, std::shared_ptr const>::doVisit(std::shared_ptr const&) @ 0x0000000032ebacf5 6. ./src/Interpreters/InDepthNodeVisitor.h:61: void DB::InDepthNodeVisitor, false, false, std::shared_ptr const>::visitChildren(std::shared_ptr const&) @ 0x0000000032ebb1ef 7. ./src/Interpreters/InDepthNodeVisitor.h:59: void DB::InDepthNodeVisitor, false, false, std::shared_ptr const>::visitChildren(std::shared_ptr const&) @ 0x0000000032ebb1e4 8. ./src/Interpreters/InDepthNodeVisitor.h:59: void DB::InDepthNodeVisitor, false, false, std::shared_ptr const>::visitChildren(std::shared_ptr const&) @ 0x0000000032ebb1e4 9. ./src/Interpreters/InDepthNodeVisitor.h:59: void DB::InDepthNodeVisitor, false, false, std::shared_ptr const>::visitChildren(std::shared_ptr const&) @ 0x0000000032ebb1e4 10. ./src/Interpreters/InDepthNodeVisitor.h:59: void DB::InDepthNodeVisitor, false, false, std::shared_ptr const>::visitChildren(std::shared_ptr const&) @ 0x0000000032ebb1e4 11. ./src/Interpreters/InDepthNodeVisitor.h:59: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x000000003351f9c2 12. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1527: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000335251ec 13. ./build_docker/./src/Storages/ColumnsDescription.cpp:1017: DB::(anonymous namespace)::validateColumnsDefaultsAndGetSampleBlockImpl(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr, bool) @ 0x00000000381e3e3f 14. ./build_docker/./src/Storages/ColumnsDescription.cpp:1044: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000381e5633 15. ./build_docker/./src/Databases/DatabasesCommon.cpp:91: DB::applyMetadataChangesToCreateQuery(std::shared_ptr const&, DB::StorageInMemoryMetadata const&, std::shared_ptr) @ 0x000000002f9c92d3 16. ./build_docker/./src/Databases/DatabaseOrdinary.cpp:611: DB::DatabaseOrdinary::alterTable(std::shared_ptr, DB::StorageID const&, DB::StorageInMemoryMetadata const&) @ 0x000000002f8b9bfc 17. ./build_docker/./src/Storages/StorageMergeTree.cpp:441: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003a39e125 18. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 19. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 29. ? @ 0x00007f5206343ac3 30. ? @ 0x00007f52063d5850 2025.06.13 09:04:45.798989 [ 9224 ] {9840fe59-5919-49ab-a47f-6e484a2f8222} executeQuery: Code: 44. DB::Exception: Destination Variant(Float32, String) and Avro Union containing Float64 are not compatible. If this is an issue, then let the Input Format infer the schema from the Avro message instead of providing custom Variant type.: column double_or_string: (while reading header): (in file/uri /var/lib/clickhouse/user_files/union_in_complex_types.avro): While executing AvroRowInputFormat: While executing File. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57872) (comment: 03237_avro_union_in_complex_types.sh) (query 1, line 1) (in query: select * from file('union_in_complex_types.avro', 'Avro', ' string_only String, string_or_null Nullable(String), null_or_string Nullable(String), double_or_string Variant(Float32, String), string_or_double Variant(Float32, String), null_or_string_or_double Variant(Float32, String), string_or_double_or_null Variant(Float32, String), string_or_float_or_long Variant(Float32, Int64, String), long_or_string_or_float Variant(Float32, Int64, String), double_or_null_or_string_or_long Variant(Float32, String, Int64), double_or_long_or_string_in_array Array(Variant(Float32, String, Int64)), double_or_string_or_long_or_null_in_map Map(String, Variant(Float32, Int64, String)) ');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Processors/Formats/Impl/AvroRowInputFormat.cpp:461: DB::AvroDeserializer::createDeserializeFn(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003b1dcf12 5. ./build_docker/./src/Processors/Formats/Impl/AvroRowInputFormat.cpp:869: DB::AvroDeserializer::createAction(DB::Block const&, std::shared_ptr const&, String const&) @ 0x000000003b1f1819 6. ./build_docker/./src/Processors/Formats/Impl/AvroRowInputFormat.cpp:886: DB::AvroDeserializer::createAction(DB::Block const&, std::shared_ptr const&, String const&) @ 0x000000003b1f1bff 7. ./build_docker/./src/Processors/Formats/Impl/AvroRowInputFormat.cpp:978: DB::AvroDeserializer::AvroDeserializer(DB::Block const&, avro::ValidSchema, bool, bool, DB::FormatSettings const&) @ 0x000000003b1f7588 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::AvroRowInputFormat::readPrefix() @ 0x000000003b1f86ed 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:97: DB::IRowInputFormat::read() @ 0x000000003b27428b 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b108bd9 11. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 12. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 17. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000038415cf2 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 09:04:45.826716 [ 9224 ] {} TCPHandler: Code: 44. DB::Exception: Destination Variant(Float32, String) and Avro Union containing Float64 are not compatible. If this is an issue, then let the Input Format infer the schema from the Avro message instead of providing custom Variant type.: column double_or_string: (while reading header): (in file/uri /var/lib/clickhouse/user_files/union_in_complex_types.avro): While executing AvroRowInputFormat: While executing File. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Processors/Formats/Impl/AvroRowInputFormat.cpp:461: DB::AvroDeserializer::createDeserializeFn(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003b1dcf12 5. ./build_docker/./src/Processors/Formats/Impl/AvroRowInputFormat.cpp:869: DB::AvroDeserializer::createAction(DB::Block const&, std::shared_ptr const&, String const&) @ 0x000000003b1f1819 6. ./build_docker/./src/Processors/Formats/Impl/AvroRowInputFormat.cpp:886: DB::AvroDeserializer::createAction(DB::Block const&, std::shared_ptr const&, String const&) @ 0x000000003b1f1bff 7. ./build_docker/./src/Processors/Formats/Impl/AvroRowInputFormat.cpp:978: DB::AvroDeserializer::AvroDeserializer(DB::Block const&, avro::ValidSchema, bool, bool, DB::FormatSettings const&) @ 0x000000003b1f7588 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::AvroRowInputFormat::readPrefix() @ 0x000000003b1f86ed 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:97: DB::IRowInputFormat::read() @ 0x000000003b27428b 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b108bd9 11. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 12. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 17. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000038415cf2 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:04:47.075260 [ 9224 ] {32207ccb-acc0-44b4-819b-76c8ed3c2718} executeQuery: Code: 36. DB::Exception: The number of (non-null) union types in Avro record (2) does not match the number of types in destination Variant type (3).: column double_or_string: (while reading header): (in file/uri /var/lib/clickhouse/user_files/union_in_complex_types.avro): While executing AvroRowInputFormat: While executing File. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57886) (comment: 03237_avro_union_in_complex_types.sh) (query 1, line 1) (in query: select * from file('union_in_complex_types.avro', 'Avro', ' string_only String, string_or_null Nullable(String), null_or_string Nullable(String), double_or_string Variant(Float64, String, Int64), string_or_double Variant(Float64, String, Int64), null_or_string_or_double Variant(Float64, String, Int64), string_or_double_or_null Variant(Float64, String, Int64), string_or_float_or_long Variant(Float32, Int64, String, Int64), long_or_string_or_float Variant(Float32, Int64, String, Int64), double_or_null_or_string_or_long Variant(Float64, String, Int64, Int64), double_or_long_or_string_in_array Array(Variant(Float64, String, Int64)), double_or_string_or_long_or_null_in_map Map(String, Variant(Float64, Int64, String)) ');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x000000001f509a6d 4. ./build_docker/./src/Processors/Formats/Impl/AvroRowInputFormat.cpp:472: DB::AvroDeserializer::createDeserializeFn(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003b1dd8a3 5. ./build_docker/./src/Processors/Formats/Impl/AvroRowInputFormat.cpp:869: DB::AvroDeserializer::createAction(DB::Block const&, std::shared_ptr const&, String const&) @ 0x000000003b1f1819 6. ./build_docker/./src/Processors/Formats/Impl/AvroRowInputFormat.cpp:886: DB::AvroDeserializer::createAction(DB::Block const&, std::shared_ptr const&, String const&) @ 0x000000003b1f1bff 7. ./build_docker/./src/Processors/Formats/Impl/AvroRowInputFormat.cpp:978: DB::AvroDeserializer::AvroDeserializer(DB::Block const&, avro::ValidSchema, bool, bool, DB::FormatSettings const&) @ 0x000000003b1f7588 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::AvroRowInputFormat::readPrefix() @ 0x000000003b1f86ed 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:97: DB::IRowInputFormat::read() @ 0x000000003b27428b 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b108bd9 11. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 12. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 17. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000038415cf2 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 09:04:47.098668 [ 9224 ] {} TCPHandler: Code: 36. DB::Exception: The number of (non-null) union types in Avro record (2) does not match the number of types in destination Variant type (3).: column double_or_string: (while reading header): (in file/uri /var/lib/clickhouse/user_files/union_in_complex_types.avro): While executing AvroRowInputFormat: While executing File. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x000000001f509a6d 4. ./build_docker/./src/Processors/Formats/Impl/AvroRowInputFormat.cpp:472: DB::AvroDeserializer::createDeserializeFn(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003b1dd8a3 5. ./build_docker/./src/Processors/Formats/Impl/AvroRowInputFormat.cpp:869: DB::AvroDeserializer::createAction(DB::Block const&, std::shared_ptr const&, String const&) @ 0x000000003b1f1819 6. ./build_docker/./src/Processors/Formats/Impl/AvroRowInputFormat.cpp:886: DB::AvroDeserializer::createAction(DB::Block const&, std::shared_ptr const&, String const&) @ 0x000000003b1f1bff 7. ./build_docker/./src/Processors/Formats/Impl/AvroRowInputFormat.cpp:978: DB::AvroDeserializer::AvroDeserializer(DB::Block const&, avro::ValidSchema, bool, bool, DB::FormatSettings const&) @ 0x000000003b1f7588 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::AvroRowInputFormat::readPrefix() @ 0x000000003b1f86ed 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:97: DB::IRowInputFormat::read() @ 0x000000003b27428b 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b108bd9 11. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 12. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 17. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000038415cf2 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:04:48.306871 [ 9224 ] {426ed193-c079-4f94-bc14-ffc56b8555d7} executeQuery: Code: 44. DB::Exception: Destination Variant(Float64, Int64) and Avro Union containing String are not compatible. If this is an issue, then let the Input Format infer the schema from the Avro message instead of providing custom Variant type.: column double_or_string_or_long_or_null_in_map: (while reading header): (in file/uri /var/lib/clickhouse/user_files/union_in_complex_types.avro): While executing AvroRowInputFormat: While executing File. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57892) (comment: 03237_avro_union_in_complex_types.sh) (query 1, line 1) (in query: select * from file('union_in_complex_types.avro', 'Avro', ' string_only String, string_or_null Nullable(String), null_or_string Nullable(String), double_or_string Variant(Float64, String), string_or_double Variant(Float64, String), null_or_string_or_double Variant(Float64, String), string_or_double_or_null Variant(Float64, String), string_or_float_or_long Variant(Float32, Int64, String), long_or_string_or_float Variant(Float32, Int64, String), double_or_null_or_string_or_long Variant(Float64, String, Int64), double_or_long_or_string_in_array Array(Variant(Float64, String, Int64)), double_or_string_or_long_or_null_in_map Map(String, Variant(Float64, Int64)) ');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Processors/Formats/Impl/AvroRowInputFormat.cpp:461: DB::AvroDeserializer::createDeserializeFn(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003b1dcf12 5. ./build_docker/./src/Processors/Formats/Impl/AvroRowInputFormat.cpp:660: DB::AvroDeserializer::createDeserializeFn(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003b1dc034 6. ./build_docker/./src/Processors/Formats/Impl/AvroRowInputFormat.cpp:869: DB::AvroDeserializer::createAction(DB::Block const&, std::shared_ptr const&, String const&) @ 0x000000003b1f1819 7. ./build_docker/./src/Processors/Formats/Impl/AvroRowInputFormat.cpp:886: DB::AvroDeserializer::createAction(DB::Block const&, std::shared_ptr const&, String const&) @ 0x000000003b1f1bff 8. ./build_docker/./src/Processors/Formats/Impl/AvroRowInputFormat.cpp:978: DB::AvroDeserializer::AvroDeserializer(DB::Block const&, avro::ValidSchema, bool, bool, DB::FormatSettings const&) @ 0x000000003b1f7588 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::AvroRowInputFormat::readPrefix() @ 0x000000003b1f86ed 10. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:97: DB::IRowInputFormat::read() @ 0x000000003b27428b 11. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b108bd9 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 18. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000038415cf2 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 29. ? @ 0x00007f5206343ac3 30. ? @ 0x00007f52063d5850 2025.06.13 09:04:48.328491 [ 9224 ] {} TCPHandler: Code: 44. DB::Exception: Destination Variant(Float64, Int64) and Avro Union containing String are not compatible. If this is an issue, then let the Input Format infer the schema from the Avro message instead of providing custom Variant type.: column double_or_string_or_long_or_null_in_map: (while reading header): (in file/uri /var/lib/clickhouse/user_files/union_in_complex_types.avro): While executing AvroRowInputFormat: While executing File. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Processors/Formats/Impl/AvroRowInputFormat.cpp:461: DB::AvroDeserializer::createDeserializeFn(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003b1dcf12 5. ./build_docker/./src/Processors/Formats/Impl/AvroRowInputFormat.cpp:660: DB::AvroDeserializer::createDeserializeFn(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003b1dc034 6. ./build_docker/./src/Processors/Formats/Impl/AvroRowInputFormat.cpp:869: DB::AvroDeserializer::createAction(DB::Block const&, std::shared_ptr const&, String const&) @ 0x000000003b1f1819 7. ./build_docker/./src/Processors/Formats/Impl/AvroRowInputFormat.cpp:886: DB::AvroDeserializer::createAction(DB::Block const&, std::shared_ptr const&, String const&) @ 0x000000003b1f1bff 8. ./build_docker/./src/Processors/Formats/Impl/AvroRowInputFormat.cpp:978: DB::AvroDeserializer::AvroDeserializer(DB::Block const&, avro::ValidSchema, bool, bool, DB::FormatSettings const&) @ 0x000000003b1f7588 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::AvroRowInputFormat::readPrefix() @ 0x000000003b1f86ed 10. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:97: DB::IRowInputFormat::read() @ 0x000000003b27428b 11. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b108bd9 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 18. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000038415cf2 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 29. ? @ 0x00007f5206343ac3 30. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:04:58.742634 [ 405 ] {f2172554-cfaa-4631-b06c-5334c8debaea} executeQuery: Code: 36. DB::Exception: The second root is not allowed. You should probably add 'PARENT all' clause. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53236) (comment: 03232_workloads_and_resources.sql) (query 7, line 12) (in query: -- Test that illegal actions are not allowed create workload another_root;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Common/Scheduler/Workload/WorkloadEntityStorageBase.cpp:397: DB::WorkloadEntityStorageBase::storeEntity(std::shared_ptr const&, DB::WorkloadEntityType, String const&, std::shared_ptr, bool, bool, DB::Settings const&) @ 0x000000003191613a 5. ./build_docker/./src/Interpreters/InterpreterCreateWorkloadQuery.cpp:47: DB::InterpreterCreateWorkloadQuery::execute() @ 0x00000000338d7f39 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:04:58.750443 [ 405 ] {} TCPHandler: Code: 36. DB::Exception: The second root is not allowed. You should probably add 'PARENT all' clause. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Common/Scheduler/Workload/WorkloadEntityStorageBase.cpp:397: DB::WorkloadEntityStorageBase::storeEntity(std::shared_ptr const&, DB::WorkloadEntityType, String const&, std::shared_ptr, bool, bool, DB::Settings const&) @ 0x000000003191613a 5. ./build_docker/./src/Interpreters/InterpreterCreateWorkloadQuery.cpp:47: DB::InterpreterCreateWorkloadQuery::execute() @ 0x00000000338d7f39 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:04:58.895681 [ 405 ] {cdb5c42e-c7bd-4440-8816-b7e40bb5d7ac} executeQuery: Code: 36. DB::Exception: Workload entity 'self_ref' references another workload entity 'self_ref' that doesn't exist. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53236) (comment: 03232_workloads_and_resources.sql) (query 8, line 14) (in query: create workload self_ref in self_ref;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000008bb626d 4. ./build_docker/./src/Common/Scheduler/Workload/WorkloadEntityStorageBase.cpp:408: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WorkloadEntityType, String const&, std::shared_ptr, bool, bool, DB::Settings const&)::$_0, void (String const&, String const&, DB::(anonymous namespace)::ReferenceType)>>(std::__function::__policy_storage const*, String const&, String const&, DB::(anonymous namespace)::ReferenceType) @ 0x0000000031938fbd 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031916d6c 6. ./build_docker/./src/Common/Scheduler/Workload/WorkloadEntityStorageBase.cpp:404: DB::WorkloadEntityStorageBase::storeEntity(std::shared_ptr const&, DB::WorkloadEntityType, String const&, std::shared_ptr, bool, bool, DB::Settings const&) @ 0x0000000031915078 7. ./build_docker/./src/Interpreters/InterpreterCreateWorkloadQuery.cpp:47: DB::InterpreterCreateWorkloadQuery::execute() @ 0x00000000338d7f39 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:04:58.902156 [ 405 ] {} TCPHandler: Code: 36. DB::Exception: Workload entity 'self_ref' references another workload entity 'self_ref' that doesn't exist. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000008bb626d 4. ./build_docker/./src/Common/Scheduler/Workload/WorkloadEntityStorageBase.cpp:408: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WorkloadEntityType, String const&, std::shared_ptr, bool, bool, DB::Settings const&)::$_0, void (String const&, String const&, DB::(anonymous namespace)::ReferenceType)>>(std::__function::__policy_storage const*, String const&, String const&, DB::(anonymous namespace)::ReferenceType) @ 0x0000000031938fbd 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031916d6c 6. ./build_docker/./src/Common/Scheduler/Workload/WorkloadEntityStorageBase.cpp:404: DB::WorkloadEntityStorageBase::storeEntity(std::shared_ptr const&, DB::WorkloadEntityType, String const&, std::shared_ptr, bool, bool, DB::Settings const&) @ 0x0000000031915078 7. ./build_docker/./src/Interpreters/InterpreterCreateWorkloadQuery.cpp:47: DB::InterpreterCreateWorkloadQuery::execute() @ 0x00000000338d7f39 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:04:59.029946 [ 405 ] {98697b85-97f7-4828-8e87-81b59ef83906} executeQuery: Code: 36. DB::Exception: Workload entity 'all' cannot be dropped. It is referenced by: production development admin. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53236) (comment: 03232_workloads_and_resources.sql) (query 9, line 15) (in query: drop workload all;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&) @ 0x000000001ffa1a4d 4. ./build_docker/./src/Common/Scheduler/Workload/WorkloadEntityStorageBase.cpp:483: DB::WorkloadEntityStorageBase::removeEntity(std::shared_ptr const&, DB::WorkloadEntityType, String const&, bool) @ 0x000000003191bb2a 5. ./build_docker/./src/Interpreters/InterpreterDropWorkloadQuery.cpp:42: DB::InterpreterDropWorkloadQuery::execute() @ 0x00000000338d9c0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:04:59.036542 [ 405 ] {} TCPHandler: Code: 36. DB::Exception: Workload entity 'all' cannot be dropped. It is referenced by: production development admin. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&) @ 0x000000001ffa1a4d 4. ./build_docker/./src/Common/Scheduler/Workload/WorkloadEntityStorageBase.cpp:483: DB::WorkloadEntityStorageBase::removeEntity(std::shared_ptr const&, DB::WorkloadEntityType, String const&, bool) @ 0x000000003191bb2a 5. ./build_docker/./src/Interpreters/InterpreterDropWorkloadQuery.cpp:42: DB::InterpreterDropWorkloadQuery::execute() @ 0x00000000338d9c0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:04:59.182096 [ 405 ] {08653955-9b89-4e10-852b-004e148485fa} executeQuery: Code: 36. DB::Exception: Workload parent should reference another workload, not '03232_write'. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53236) (comment: 03232_workloads_and_resources.sql) (query 10, line 16) (in query: create workload invalid in 03232_write;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Common/Scheduler/Workload/WorkloadEntityStorageBase.cpp:415: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WorkloadEntityType, String const&, std::shared_ptr, bool, bool, DB::Settings const&)::$_0, void (String const&, String const&, DB::(anonymous namespace)::ReferenceType)>>(std::__function::__policy_storage const*, String const&, String const&, DB::(anonymous namespace)::ReferenceType) @ 0x0000000031939257 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031916d6c 6. ./build_docker/./src/Common/Scheduler/Workload/WorkloadEntityStorageBase.cpp:404: DB::WorkloadEntityStorageBase::storeEntity(std::shared_ptr const&, DB::WorkloadEntityType, String const&, std::shared_ptr, bool, bool, DB::Settings const&) @ 0x0000000031915078 7. ./build_docker/./src/Interpreters/InterpreterCreateWorkloadQuery.cpp:47: DB::InterpreterCreateWorkloadQuery::execute() @ 0x00000000338d7f39 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:04:59.188623 [ 405 ] {} TCPHandler: Code: 36. DB::Exception: Workload parent should reference another workload, not '03232_write'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Common/Scheduler/Workload/WorkloadEntityStorageBase.cpp:415: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WorkloadEntityType, String const&, std::shared_ptr, bool, bool, DB::Settings const&)::$_0, void (String const&, String const&, DB::(anonymous namespace)::ReferenceType)>>(std::__function::__policy_storage const*, String const&, String const&, DB::(anonymous namespace)::ReferenceType) @ 0x0000000031939257 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031916d6c 6. ./build_docker/./src/Common/Scheduler/Workload/WorkloadEntityStorageBase.cpp:404: DB::WorkloadEntityStorageBase::storeEntity(std::shared_ptr const&, DB::WorkloadEntityType, String const&, std::shared_ptr, bool, bool, DB::Settings const&) @ 0x0000000031915078 7. ./build_docker/./src/Interpreters/InterpreterCreateWorkloadQuery.cpp:47: DB::InterpreterCreateWorkloadQuery::execute() @ 0x00000000338d7f39 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:04:59.334625 [ 405 ] {93881f6f-4dd8-473b-9e02-d636731d74ac} executeQuery: Code: 36. DB::Exception: Workload settings should reference resource in FOR clause, not 'all'. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53236) (comment: 03232_workloads_and_resources.sql) (query 11, line 17) (in query: create workload invalid in all settings priority = 0 for all;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Common/Scheduler/Workload/WorkloadEntityStorageBase.cpp:421: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WorkloadEntityType, String const&, std::shared_ptr, bool, bool, DB::Settings const&)::$_0, void (String const&, String const&, DB::(anonymous namespace)::ReferenceType)>>(std::__function::__policy_storage const*, String const&, String const&, DB::(anonymous namespace)::ReferenceType) @ 0x0000000031938e85 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031917085 6. ./build_docker/./src/Common/Scheduler/Workload/WorkloadEntityStorageBase.cpp:404: DB::WorkloadEntityStorageBase::storeEntity(std::shared_ptr const&, DB::WorkloadEntityType, String const&, std::shared_ptr, bool, bool, DB::Settings const&) @ 0x0000000031915078 7. ./build_docker/./src/Interpreters/InterpreterCreateWorkloadQuery.cpp:47: DB::InterpreterCreateWorkloadQuery::execute() @ 0x00000000338d7f39 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:04:59.341111 [ 405 ] {} TCPHandler: Code: 36. DB::Exception: Workload settings should reference resource in FOR clause, not 'all'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Common/Scheduler/Workload/WorkloadEntityStorageBase.cpp:421: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WorkloadEntityType, String const&, std::shared_ptr, bool, bool, DB::Settings const&)::$_0, void (String const&, String const&, DB::(anonymous namespace)::ReferenceType)>>(std::__function::__policy_storage const*, String const&, String const&, DB::(anonymous namespace)::ReferenceType) @ 0x0000000031938e85 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031917085 6. ./build_docker/./src/Common/Scheduler/Workload/WorkloadEntityStorageBase.cpp:404: DB::WorkloadEntityStorageBase::storeEntity(std::shared_ptr const&, DB::WorkloadEntityType, String const&, std::shared_ptr, bool, bool, DB::Settings const&) @ 0x0000000031915078 7. ./build_docker/./src/Interpreters/InterpreterCreateWorkloadQuery.cpp:47: DB::InterpreterCreateWorkloadQuery::execute() @ 0x00000000338d7f39 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:04:59.491346 [ 405 ] {7925e2d0-766b-49ea-bc08-13039033b236} executeQuery: Code: 170. DB::Exception: Bad get: has String, requested Int64. (BAD_GET) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53236) (comment: 03232_workloads_and_resources.sql) (query 12, line 18) (in query: create workload invalid in all settings priority = 'invalid_value';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>, std::basic_string_view>>(int, FormatStringHelperImpl>>::type, std::type_identity>>::type>, std::basic_string_view>&&, std::basic_string_view>&&) @ 0x000000002eaaafad 4. ./build_docker/./src/Core/Field.cpp:842: DB::NearestFieldTypeImpl<__decay(long), void>::Type& DB::Field::safeGet() & @ 0x000000002eaad343 5. ./src/Core/Field.h:434: DB::SchedulingSettings::updateFromChanges(std::vector> const&, String const&)::$_0::read(String const&, DB::Field const&) @ 0x00000000318fadeb 6. ./build_docker/./src/Common/Scheduler/SchedulingSettings.cpp:0: DB::SchedulingSettings::updateFromChanges(std::vector> const&, String const&) @ 0x00000000318f9d69 7. ./build_docker/./src/Common/Scheduler/Workload/WorkloadEntityStorageBase.cpp:401: DB::WorkloadEntityStorageBase::storeEntity(std::shared_ptr const&, DB::WorkloadEntityType, String const&, std::shared_ptr, bool, bool, DB::Settings const&) @ 0x0000000031914f7e 8. ./build_docker/./src/Interpreters/InterpreterCreateWorkloadQuery.cpp:47: DB::InterpreterCreateWorkloadQuery::execute() @ 0x00000000338d7f39 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:04:59.498588 [ 405 ] {} TCPHandler: Code: 170. DB::Exception: Bad get: has String, requested Int64. (BAD_GET), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>, std::basic_string_view>>(int, FormatStringHelperImpl>>::type, std::type_identity>>::type>, std::basic_string_view>&&, std::basic_string_view>&&) @ 0x000000002eaaafad 4. ./build_docker/./src/Core/Field.cpp:842: DB::NearestFieldTypeImpl<__decay(long), void>::Type& DB::Field::safeGet() & @ 0x000000002eaad343 5. ./src/Core/Field.h:434: DB::SchedulingSettings::updateFromChanges(std::vector> const&, String const&)::$_0::read(String const&, DB::Field const&) @ 0x00000000318fadeb 6. ./build_docker/./src/Common/Scheduler/SchedulingSettings.cpp:0: DB::SchedulingSettings::updateFromChanges(std::vector> const&, String const&) @ 0x00000000318f9d69 7. ./build_docker/./src/Common/Scheduler/Workload/WorkloadEntityStorageBase.cpp:401: DB::WorkloadEntityStorageBase::storeEntity(std::shared_ptr const&, DB::WorkloadEntityType, String const&, std::shared_ptr, bool, bool, DB::Settings const&) @ 0x0000000031914f7e 8. ./build_docker/./src/Interpreters/InterpreterCreateWorkloadQuery.cpp:47: DB::InterpreterCreateWorkloadQuery::execute() @ 0x00000000338d7f39 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:04:59.637730 [ 405 ] {2479bd66-b7ee-4a3f-9b1a-52eaae65a4ff} executeQuery: Code: 672. DB::Exception: Zero, negative and non-finite node weights are not allowed: 0. (INVALID_SCHEDULER_NODE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53236) (comment: 03232_workloads_and_resources.sql) (query 13, line 19) (in query: create workload invalid in all settings weight = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, double&) @ 0x000000001aa34f0a 4. ./src/Common/Scheduler/ISchedulerNode.h:75: DB::SchedulingSettings::updateFromChanges(std::vector> const&, String const&) @ 0x00000000318fa606 5. ./build_docker/./src/Common/Scheduler/Workload/WorkloadEntityStorageBase.cpp:401: DB::WorkloadEntityStorageBase::storeEntity(std::shared_ptr const&, DB::WorkloadEntityType, String const&, std::shared_ptr, bool, bool, DB::Settings const&) @ 0x0000000031914f7e 6. ./build_docker/./src/Interpreters/InterpreterCreateWorkloadQuery.cpp:47: DB::InterpreterCreateWorkloadQuery::execute() @ 0x00000000338d7f39 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:04:59.644243 [ 405 ] {} TCPHandler: Code: 672. DB::Exception: Zero, negative and non-finite node weights are not allowed: 0. (INVALID_SCHEDULER_NODE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, double&) @ 0x000000001aa34f0a 4. ./src/Common/Scheduler/ISchedulerNode.h:75: DB::SchedulingSettings::updateFromChanges(std::vector> const&, String const&) @ 0x00000000318fa606 5. ./build_docker/./src/Common/Scheduler/Workload/WorkloadEntityStorageBase.cpp:401: DB::WorkloadEntityStorageBase::storeEntity(std::shared_ptr const&, DB::WorkloadEntityType, String const&, std::shared_ptr, bool, bool, DB::Settings const&) @ 0x0000000031914f7e 6. ./build_docker/./src/Interpreters/InterpreterCreateWorkloadQuery.cpp:47: DB::InterpreterCreateWorkloadQuery::execute() @ 0x00000000338d7f39 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:04:59.792675 [ 405 ] {66f6dbb9-4889-4313-bc94-12b9cc668b9a} executeQuery: Code: 36. DB::Exception: Unexpected negative Int64 value for workload setting 'weight'. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53236) (comment: 03232_workloads_and_resources.sql) (query 14, line 20) (in query: create workload invalid in all settings weight = -1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Common/Scheduler/SchedulingSettings.cpp:38: DB::SchedulingSettings::updateFromChanges(std::vector> const&, String const&)::$_0::getNotNegativeFloat64(String const&, DB::Field const&) @ 0x00000000318fb149 5. ./build_docker/./src/Common/Scheduler/SchedulingSettings.cpp:75: DB::SchedulingSettings::updateFromChanges(std::vector> const&, String const&)::$_0::read(String const&, DB::Field const&) @ 0x00000000318faa4a 6. ./build_docker/./src/Common/Scheduler/SchedulingSettings.cpp:0: DB::SchedulingSettings::updateFromChanges(std::vector> const&, String const&) @ 0x00000000318f9d69 7. ./build_docker/./src/Common/Scheduler/Workload/WorkloadEntityStorageBase.cpp:401: DB::WorkloadEntityStorageBase::storeEntity(std::shared_ptr const&, DB::WorkloadEntityType, String const&, std::shared_ptr, bool, bool, DB::Settings const&) @ 0x0000000031914f7e 8. ./build_docker/./src/Interpreters/InterpreterCreateWorkloadQuery.cpp:47: DB::InterpreterCreateWorkloadQuery::execute() @ 0x00000000338d7f39 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:04:59.799183 [ 405 ] {} TCPHandler: Code: 36. DB::Exception: Unexpected negative Int64 value for workload setting 'weight'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Common/Scheduler/SchedulingSettings.cpp:38: DB::SchedulingSettings::updateFromChanges(std::vector> const&, String const&)::$_0::getNotNegativeFloat64(String const&, DB::Field const&) @ 0x00000000318fb149 5. ./build_docker/./src/Common/Scheduler/SchedulingSettings.cpp:75: DB::SchedulingSettings::updateFromChanges(std::vector> const&, String const&)::$_0::read(String const&, DB::Field const&) @ 0x00000000318faa4a 6. ./build_docker/./src/Common/Scheduler/SchedulingSettings.cpp:0: DB::SchedulingSettings::updateFromChanges(std::vector> const&, String const&) @ 0x00000000318f9d69 7. ./build_docker/./src/Common/Scheduler/Workload/WorkloadEntityStorageBase.cpp:401: DB::WorkloadEntityStorageBase::storeEntity(std::shared_ptr const&, DB::WorkloadEntityType, String const&, std::shared_ptr, bool, bool, DB::Settings const&) @ 0x0000000031914f7e 8. ./build_docker/./src/Interpreters/InterpreterCreateWorkloadQuery.cpp:47: DB::InterpreterCreateWorkloadQuery::execute() @ 0x00000000338d7f39 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:04:59.948354 [ 405 ] {1f401b38-c272-4dc6-832d-6f3fa04058cf} executeQuery: Code: 36. DB::Exception: Unexpected negative Int64 value for workload setting 'max_speed'. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53236) (comment: 03232_workloads_and_resources.sql) (query 15, line 21) (in query: create workload invalid in all settings max_speed = -1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Common/Scheduler/SchedulingSettings.cpp:38: DB::SchedulingSettings::updateFromChanges(std::vector> const&, String const&)::$_0::getNotNegativeFloat64(String const&, DB::Field const&) @ 0x00000000318fb149 5. ./build_docker/./src/Common/Scheduler/SchedulingSettings.cpp:79: DB::SchedulingSettings::updateFromChanges(std::vector> const&, String const&)::$_0::read(String const&, DB::Field const&) @ 0x00000000318fadba 6. ./build_docker/./src/Common/Scheduler/SchedulingSettings.cpp:0: DB::SchedulingSettings::updateFromChanges(std::vector> const&, String const&) @ 0x00000000318f9d69 7. ./build_docker/./src/Common/Scheduler/Workload/WorkloadEntityStorageBase.cpp:401: DB::WorkloadEntityStorageBase::storeEntity(std::shared_ptr const&, DB::WorkloadEntityType, String const&, std::shared_ptr, bool, bool, DB::Settings const&) @ 0x0000000031914f7e 8. ./build_docker/./src/Interpreters/InterpreterCreateWorkloadQuery.cpp:47: DB::InterpreterCreateWorkloadQuery::execute() @ 0x00000000338d7f39 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:04:59.954878 [ 405 ] {} TCPHandler: Code: 36. DB::Exception: Unexpected negative Int64 value for workload setting 'max_speed'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Common/Scheduler/SchedulingSettings.cpp:38: DB::SchedulingSettings::updateFromChanges(std::vector> const&, String const&)::$_0::getNotNegativeFloat64(String const&, DB::Field const&) @ 0x00000000318fb149 5. ./build_docker/./src/Common/Scheduler/SchedulingSettings.cpp:79: DB::SchedulingSettings::updateFromChanges(std::vector> const&, String const&)::$_0::read(String const&, DB::Field const&) @ 0x00000000318fadba 6. ./build_docker/./src/Common/Scheduler/SchedulingSettings.cpp:0: DB::SchedulingSettings::updateFromChanges(std::vector> const&, String const&) @ 0x00000000318f9d69 7. ./build_docker/./src/Common/Scheduler/Workload/WorkloadEntityStorageBase.cpp:401: DB::WorkloadEntityStorageBase::storeEntity(std::shared_ptr const&, DB::WorkloadEntityType, String const&, std::shared_ptr, bool, bool, DB::Settings const&) @ 0x0000000031914f7e 8. ./build_docker/./src/Interpreters/InterpreterCreateWorkloadQuery.cpp:47: DB::InterpreterCreateWorkloadQuery::execute() @ 0x00000000338d7f39 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:05:00.104156 [ 405 ] {10e18749-3fbf-4cbc-85eb-02524a0624b2} executeQuery: Code: 36. DB::Exception: Unexpected negative Int64 value for workload setting 'max_cost'. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53236) (comment: 03232_workloads_and_resources.sql) (query 16, line 22) (in query: create workload invalid in all settings max_cost = -1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Common/Scheduler/SchedulingSettings.cpp:64: DB::SchedulingSettings::updateFromChanges(std::vector> const&, String const&)::$_0::getNotNegativeInt64(String const&, DB::Field const&) @ 0x00000000318fb3bb 5. ./build_docker/./src/Common/Scheduler/SchedulingSettings.cpp:85: DB::SchedulingSettings::updateFromChanges(std::vector> const&, String const&)::$_0::read(String const&, DB::Field const&) @ 0x00000000318facea 6. ./build_docker/./src/Common/Scheduler/SchedulingSettings.cpp:0: DB::SchedulingSettings::updateFromChanges(std::vector> const&, String const&) @ 0x00000000318f9d69 7. ./build_docker/./src/Common/Scheduler/Workload/WorkloadEntityStorageBase.cpp:401: DB::WorkloadEntityStorageBase::storeEntity(std::shared_ptr const&, DB::WorkloadEntityType, String const&, std::shared_ptr, bool, bool, DB::Settings const&) @ 0x0000000031914f7e 8. ./build_docker/./src/Interpreters/InterpreterCreateWorkloadQuery.cpp:47: DB::InterpreterCreateWorkloadQuery::execute() @ 0x00000000338d7f39 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:05:00.110967 [ 405 ] {} TCPHandler: Code: 36. DB::Exception: Unexpected negative Int64 value for workload setting 'max_cost'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Common/Scheduler/SchedulingSettings.cpp:64: DB::SchedulingSettings::updateFromChanges(std::vector> const&, String const&)::$_0::getNotNegativeInt64(String const&, DB::Field const&) @ 0x00000000318fb3bb 5. ./build_docker/./src/Common/Scheduler/SchedulingSettings.cpp:85: DB::SchedulingSettings::updateFromChanges(std::vector> const&, String const&)::$_0::read(String const&, DB::Field const&) @ 0x00000000318facea 6. ./build_docker/./src/Common/Scheduler/SchedulingSettings.cpp:0: DB::SchedulingSettings::updateFromChanges(std::vector> const&, String const&) @ 0x00000000318f9d69 7. ./build_docker/./src/Common/Scheduler/Workload/WorkloadEntityStorageBase.cpp:401: DB::WorkloadEntityStorageBase::storeEntity(std::shared_ptr const&, DB::WorkloadEntityType, String const&, std::shared_ptr, bool, bool, DB::Settings const&) @ 0x0000000031914f7e 8. ./build_docker/./src/Interpreters/InterpreterCreateWorkloadQuery.cpp:47: DB::InterpreterCreateWorkloadQuery::execute() @ 0x00000000338d7f39 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:05:00.259985 [ 405 ] {c039e025-ac5a-4f6c-8d56-97bcea928a8b} executeQuery: Code: 36. DB::Exception: Unexpected negative Int64 value for workload setting 'max_requests'. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53236) (comment: 03232_workloads_and_resources.sql) (query 17, line 23) (in query: create workload invalid in all settings max_requests = -1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Common/Scheduler/SchedulingSettings.cpp:64: DB::SchedulingSettings::updateFromChanges(std::vector> const&, String const&)::$_0::getNotNegativeInt64(String const&, DB::Field const&) @ 0x00000000318fb3bb 5. ./build_docker/./src/Common/Scheduler/SchedulingSettings.cpp:83: DB::SchedulingSettings::updateFromChanges(std::vector> const&, String const&)::$_0::read(String const&, DB::Field const&) @ 0x00000000318fad88 6. ./build_docker/./src/Common/Scheduler/SchedulingSettings.cpp:0: DB::SchedulingSettings::updateFromChanges(std::vector> const&, String const&) @ 0x00000000318f9d69 7. ./build_docker/./src/Common/Scheduler/Workload/WorkloadEntityStorageBase.cpp:401: DB::WorkloadEntityStorageBase::storeEntity(std::shared_ptr const&, DB::WorkloadEntityType, String const&, std::shared_ptr, bool, bool, DB::Settings const&) @ 0x0000000031914f7e 8. ./build_docker/./src/Interpreters/InterpreterCreateWorkloadQuery.cpp:47: DB::InterpreterCreateWorkloadQuery::execute() @ 0x00000000338d7f39 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:05:00.266748 [ 405 ] {} TCPHandler: Code: 36. DB::Exception: Unexpected negative Int64 value for workload setting 'max_requests'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Common/Scheduler/SchedulingSettings.cpp:64: DB::SchedulingSettings::updateFromChanges(std::vector> const&, String const&)::$_0::getNotNegativeInt64(String const&, DB::Field const&) @ 0x00000000318fb3bb 5. ./build_docker/./src/Common/Scheduler/SchedulingSettings.cpp:83: DB::SchedulingSettings::updateFromChanges(std::vector> const&, String const&)::$_0::read(String const&, DB::Field const&) @ 0x00000000318fad88 6. ./build_docker/./src/Common/Scheduler/SchedulingSettings.cpp:0: DB::SchedulingSettings::updateFromChanges(std::vector> const&, String const&) @ 0x00000000318f9d69 7. ./build_docker/./src/Common/Scheduler/Workload/WorkloadEntityStorageBase.cpp:401: DB::WorkloadEntityStorageBase::storeEntity(std::shared_ptr const&, DB::WorkloadEntityType, String const&, std::shared_ptr, bool, bool, DB::Settings const&) @ 0x0000000031914f7e 8. ./build_docker/./src/Interpreters/InterpreterCreateWorkloadQuery.cpp:47: DB::InterpreterCreateWorkloadQuery::execute() @ 0x00000000338d7f39 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:05:00.416325 [ 405 ] {0f973e63-de09-40d2-8124-0449e6e11546} executeQuery: Code: 170. DB::Exception: Bad get: has Float64, requested Int64. (BAD_GET) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53236) (comment: 03232_workloads_and_resources.sql) (query 18, line 24) (in query: create workload invalid in all settings max_requests = 1.5;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>, std::basic_string_view>>(int, FormatStringHelperImpl>>::type, std::type_identity>>::type>, std::basic_string_view>&&, std::basic_string_view>&&) @ 0x000000002eaaafad 4. ./build_docker/./src/Core/Field.cpp:842: DB::NearestFieldTypeImpl<__decay(long), void>::Type& DB::Field::safeGet() & @ 0x000000002eaad343 5. ./src/Core/Field.h:434: DB::SchedulingSettings::updateFromChanges(std::vector> const&, String const&)::$_0::getNotNegativeInt64(String const&, DB::Field const&) @ 0x00000000318fb3f2 6. ./build_docker/./src/Common/Scheduler/SchedulingSettings.cpp:83: DB::SchedulingSettings::updateFromChanges(std::vector> const&, String const&)::$_0::read(String const&, DB::Field const&) @ 0x00000000318fad88 7. ./build_docker/./src/Common/Scheduler/SchedulingSettings.cpp:0: DB::SchedulingSettings::updateFromChanges(std::vector> const&, String const&) @ 0x00000000318f9d69 8. ./build_docker/./src/Common/Scheduler/Workload/WorkloadEntityStorageBase.cpp:401: DB::WorkloadEntityStorageBase::storeEntity(std::shared_ptr const&, DB::WorkloadEntityType, String const&, std::shared_ptr, bool, bool, DB::Settings const&) @ 0x0000000031914f7e 9. ./build_docker/./src/Interpreters/InterpreterCreateWorkloadQuery.cpp:47: DB::InterpreterCreateWorkloadQuery::execute() @ 0x00000000338d7f39 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:05:00.422981 [ 405 ] {} TCPHandler: Code: 170. DB::Exception: Bad get: has Float64, requested Int64. (BAD_GET), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>, std::basic_string_view>>(int, FormatStringHelperImpl>>::type, std::type_identity>>::type>, std::basic_string_view>&&, std::basic_string_view>&&) @ 0x000000002eaaafad 4. ./build_docker/./src/Core/Field.cpp:842: DB::NearestFieldTypeImpl<__decay(long), void>::Type& DB::Field::safeGet() & @ 0x000000002eaad343 5. ./src/Core/Field.h:434: DB::SchedulingSettings::updateFromChanges(std::vector> const&, String const&)::$_0::getNotNegativeInt64(String const&, DB::Field const&) @ 0x00000000318fb3f2 6. ./build_docker/./src/Common/Scheduler/SchedulingSettings.cpp:83: DB::SchedulingSettings::updateFromChanges(std::vector> const&, String const&)::$_0::read(String const&, DB::Field const&) @ 0x00000000318fad88 7. ./build_docker/./src/Common/Scheduler/SchedulingSettings.cpp:0: DB::SchedulingSettings::updateFromChanges(std::vector> const&, String const&) @ 0x00000000318f9d69 8. ./build_docker/./src/Common/Scheduler/Workload/WorkloadEntityStorageBase.cpp:401: DB::WorkloadEntityStorageBase::storeEntity(std::shared_ptr const&, DB::WorkloadEntityType, String const&, std::shared_ptr, bool, bool, DB::Settings const&) @ 0x0000000031914f7e 9. ./build_docker/./src/Interpreters/InterpreterCreateWorkloadQuery.cpp:47: DB::InterpreterCreateWorkloadQuery::execute() @ 0x00000000338d7f39 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:05:00.564120 [ 405 ] {aa2c7bbc-9968-4279-8fd5-e552582c6432} executeQuery: Code: 36. DB::Exception: It is not allowed to remove root workload. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53236) (comment: 03232_workloads_and_resources.sql) (query 19, line 25) (in query: create or replace workload all in production;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Common/Scheduler/Workload/WorkloadEntityStorageBase.cpp:388: DB::WorkloadEntityStorageBase::storeEntity(std::shared_ptr const&, DB::WorkloadEntityType, String const&, std::shared_ptr, bool, bool, DB::Settings const&) @ 0x0000000031915fc0 5. ./build_docker/./src/Interpreters/InterpreterCreateWorkloadQuery.cpp:47: DB::InterpreterCreateWorkloadQuery::execute() @ 0x00000000338d7f39 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:05:00.571109 [ 405 ] {} TCPHandler: Code: 36. DB::Exception: It is not allowed to remove root workload. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Common/Scheduler/Workload/WorkloadEntityStorageBase.cpp:388: DB::WorkloadEntityStorageBase::storeEntity(std::shared_ptr const&, DB::WorkloadEntityType, String const&, std::shared_ptr, bool, bool, DB::Settings const&) @ 0x0000000031915fc0 5. ./build_docker/./src/Interpreters/InterpreterCreateWorkloadQuery.cpp:47: DB::InterpreterCreateWorkloadQuery::execute() @ 0x00000000338d7f39 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:05:16.232624 [ 9253 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:16.232658 [ 2135 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:16.232972 [ 2085 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:16.317362 [ 2135 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:16.445982 [ 2135 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:16.555910 [ 42953 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:16.557908 [ 2085 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:16.633056 [ 9253 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:16.686444 [ 9253 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:16.695542 [ 2135 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:16.706952 [ 1053 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:16.707208 [ 1049 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:16.707380 [ 1040 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:16.707532 [ 1045 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:16.707671 [ 1050 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:16.706955 [ 1043 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:16.706952 [ 1052 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:16.706955 [ 1041 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:16.707020 [ 1051 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:16.707047 [ 1039 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:16.749963 [ 2135 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:16.751745 [ 2085 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:16.755371 [ 9253 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:16.757378 [ 1052 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:16.765215 [ 1040 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:16.771898 [ 1042 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:16.782574 [ 42954 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:16.801170 [ 42955 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:16.801342 [ 1039 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:16.868753 [ 42954 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:16.870178 [ 2135 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:16.876016 [ 1045 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:16.890951 [ 1050 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:16.897320 [ 42956 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:16.897357 [ 42957 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:16.901155 [ 42953 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:16.910693 [ 1051 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:16.910695 [ 1041 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:16.912558 [ 2135 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:16.916396 [ 1047 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:16.919762 [ 1043 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:16.974751 [ 2085 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:16.986253 [ 2135 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:16.999023 [ 1038 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.015384 [ 1051 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.021490 [ 42953 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.036995 [ 2085 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.046813 [ 1046 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.048351 [ 1043 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.072757 [ 42954 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.085083 [ 1041 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.095223 [ 2085 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.099045 [ 42953 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.106867 [ 1038 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.110510 [ 1053 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.125570 [ 2135 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.127411 [ 2085 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.127668 [ 9253 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.131602 [ 1048 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.132387 [ 1025 ] {} 17b824ca-e091-43ec-8864-f1012138c573::all_0_5_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a116c03 17. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1136b9 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 19. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.133268 [ 42953 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.133704 [ 1025 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {17b824ca-e091-43ec-8864-f1012138c573::all_0_5_1}: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a116c03 17. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1136b9 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 19. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.134638 [ 1051 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.134864 [ 1044 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.139544 [ 1043 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.162815 [ 857 ] {} test_ft1f8hxg.data_r1 (ReplicatedMergeTreePartCheckThread): We have part all_15_21_1 covering part all_15_15_0, will not check 2025.06.13 09:05:17.172887 [ 857 ] {} test_ft1f8hxg.data_r1 (ReplicatedMergeTreePartCheckThread): We have part all_15_21_1 covering part all_17_17_0, will not check 2025.06.13 09:05:17.176674 [ 857 ] {} test_ft1f8hxg.data_r1 (ReplicatedMergeTreePartCheckThread): We have part all_15_21_1 covering part all_20_20_0, will not check 2025.06.13 09:05:17.214321 [ 9253 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.226184 [ 42956 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.243906 [ 1047 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.260106 [ 1051 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.279603 [ 42955 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.307380 [ 42957 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.311087 [ 1038 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.319841 [ 1050 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.344386 [ 42953 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.346562 [ 2085 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.353823 [ 1047 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.354960 [ 1052 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.361934 [ 42954 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.369201 [ 1051 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.376463 [ 2135 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.385421 [ 1053 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.387790 [ 9253 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.397963 [ 1026 ] {} 17b824ca-e091-43ec-8864-f1012138c573::all_0_5_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a116c03 17. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1136b9 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 19. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.399846 [ 1026 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {17b824ca-e091-43ec-8864-f1012138c573::all_0_5_1}: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a116c03 17. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1136b9 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 19. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.458757 [ 2085 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.462716 [ 2135 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.465198 [ 9253 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.470140 [ 1045 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.470167 [ 1052 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.471572 [ 1043 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.539166 [ 42954 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.548145 [ 1039 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.550979 [ 42955 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.559809 [ 42956 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.560871 [ 1049 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.573950 [ 1042 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.621059 [ 9253 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.632118 [ 42953 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.633813 [ 1053 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.635940 [ 42954 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.641554 [ 1046 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.645530 [ 1025 ] {} 17b824ca-e091-43ec-8864-f1012138c573::all_22_28_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a116c03 17. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1136b9 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 19. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.646313 [ 1025 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {17b824ca-e091-43ec-8864-f1012138c573::all_22_28_1}: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a116c03 17. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1136b9 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 19. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.650760 [ 42955 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.658228 [ 1041 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.724533 [ 42953 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.728142 [ 42954 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.733656 [ 1022 ] {} 17b824ca-e091-43ec-8864-f1012138c573::all_29_34_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a116c03 17. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1136b9 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 19. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.734173 [ 1022 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {17b824ca-e091-43ec-8864-f1012138c573::all_29_34_1}: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a116c03 17. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1136b9 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 19. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.736001 [ 1043 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.748015 [ 2135 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.758575 [ 1050 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.760558 [ 42953 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.767903 [ 1047 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.794831 [ 42955 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.824041 [ 1046 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.837628 [ 9253 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.848138 [ 1017 ] {} 17b824ca-e091-43ec-8864-f1012138c573::all_22_28_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a116c03 17. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1136b9 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 19. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.848924 [ 1017 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {17b824ca-e091-43ec-8864-f1012138c573::all_22_28_1}: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a116c03 17. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1136b9 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 19. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.871042 [ 9253 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.871710 [ 2135 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.882975 [ 1041 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.885603 [ 1044 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.886755 [ 42956 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.898289 [ 1018 ] {} 17b824ca-e091-43ec-8864-f1012138c573::all_29_34_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a116c03 17. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1136b9 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 19. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.898752 [ 1018 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {17b824ca-e091-43ec-8864-f1012138c573::all_29_34_1}: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a116c03 17. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1136b9 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 19. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.961975 [ 42954 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.966875 [ 42955 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.973283 [ 1042 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:17.980561 [ 1050 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.018116 [ 42954 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.025630 [ 1044 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.029928 [ 42953 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.036482 [ 1049 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.037953 [ 9253 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.043807 [ 1045 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.064423 [ 2135 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.064930 [ 42953 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.072396 [ 1016 ] {} 17b824ca-e091-43ec-8864-f1012138c573::all_22_28_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a116c03 17. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1136b9 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 19. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.073179 [ 1016 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {17b824ca-e091-43ec-8864-f1012138c573::all_22_28_1}: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a116c03 17. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1136b9 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 19. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.073559 [ 1048 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.112002 [ 42953 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.119060 [ 1047 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.120316 [ 42954 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.121532 [ 42955 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.129274 [ 1044 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.129883 [ 1041 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.177261 [ 42955 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.182717 [ 2135 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.186420 [ 1040 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.190173 [ 1052 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.247218 [ 42953 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.248800 [ 2135 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.274394 [ 9253 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.276405 [ 1046 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.276504 [ 1043 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.284555 [ 1053 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.289762 [ 42957 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.299331 [ 1045 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.342433 [ 42955 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.343942 [ 42956 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.351016 [ 42954 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.357496 [ 1040 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.357976 [ 1041 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.359383 [ 1042 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.374678 [ 2135 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.379556 [ 42957 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.383931 [ 1051 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.386605 [ 1014 ] {} 17b824ca-e091-43ec-8864-f1012138c573::all_41_47_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a116c03 17. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1136b9 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 19. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.387146 [ 1014 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {17b824ca-e091-43ec-8864-f1012138c573::all_41_47_1}: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a116c03 17. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1136b9 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 19. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.410139 [ 2135 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.414132 [ 42955 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.420971 [ 1043 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.435877 [ 1045 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.445290 [ 2135 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.446096 [ 42956 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.451428 [ 1052 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.456141 [ 1044 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.489024 [ 42957 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.490731 [ 2135 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.497770 [ 1046 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.498854 [ 1047 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.499641 [ 42955 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.505301 [ 1048 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.544461 [ 2135 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.551291 [ 42955 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.560036 [ 1053 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.563593 [ 1051 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.573292 [ 9253 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.582750 [ 1052 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.582818 [ 42953 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.595695 [ 1043 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.614046 [ 42956 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.623870 [ 1024 ] {} 17b824ca-e091-43ec-8864-f1012138c573::all_41_47_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a116c03 17. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1136b9 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 19. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.624382 [ 1024 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {17b824ca-e091-43ec-8864-f1012138c573::all_41_47_1}: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a116c03 17. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1136b9 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 19. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.629631 [ 42957 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.634418 [ 2085 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.636810 [ 1050 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.641021 [ 1039 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.664970 [ 2135 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.676309 [ 1044 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.679241 [ 42957 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.682771 [ 42955 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.686203 [ 42956 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.689953 [ 1047 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.690441 [ 1048 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.696123 [ 1052 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.700237 [ 2135 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.717075 [ 1040 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.717944 [ 2085 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.721948 [ 42955 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.730015 [ 1051 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.734423 [ 1053 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.756169 [ 2085 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.766845 [ 42957 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.767126 [ 42953 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.769494 [ 1041 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.770536 [ 42955 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.777998 [ 1044 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.778092 [ 1042 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.778215 [ 1038 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.807835 [ 9253 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.811264 [ 42957 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.813169 [ 42955 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.821127 [ 1043 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.822545 [ 1040 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.824817 [ 1052 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.862090 [ 42957 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.867027 [ 2135 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.871137 [ 1046 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.873813 [ 42955 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.876702 [ 768 ] {} test_ft1f8hxg.data_r1 (ReplicatedMergeTreePartCheckThread): We have part all_55_61_1 covering part all_61_61_0, will not check 2025.06.13 09:05:18.878242 [ 1047 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.882187 [ 1042 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.890643 [ 42956 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.894310 [ 42953 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.898404 [ 2135 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.898680 [ 42955 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.903396 [ 1048 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.903396 [ 1038 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.913623 [ 1041 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.913758 [ 42954 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.915322 [ 1039 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.924772 [ 1043 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.967717 [ 42954 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.972004 [ 2135 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.985115 [ 1050 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:18.988345 [ 1042 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.004475 [ 42956 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.024742 [ 1052 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.026736 [ 2135 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.031310 [ 42957 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.036460 [ 1039 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.040701 [ 42955 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.044584 [ 1043 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.046796 [ 42953 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.047725 [ 1051 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.065905 [ 1046 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.103198 [ 2085 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.121871 [ 2135 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.143336 [ 1047 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.144159 [ 1044 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.153375 [ 913 ] {} test_ft1f8hxg.data_r1 (ReplicatedMergeTreePartCheckThread): We have part all_62_71_1 covering part all_67_67_0, will not check 2025.06.13 09:05:19.153940 [ 42956 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.159626 [ 913 ] {} test_ft1f8hxg.data_r1 (ReplicatedMergeTreePartCheckThread): We have part all_62_71_1 covering part all_70_70_0, will not check 2025.06.13 09:05:19.165001 [ 1045 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.180889 [ 2135 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.188343 [ 1040 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.349661 [ 42955 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.351571 [ 42954 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.354013 [ 2085 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.364985 [ 9253 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.368771 [ 1040 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.369011 [ 1046 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.370089 [ 1045 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.372689 [ 1044 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.435086 [ 42953 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.435235 [ 2135 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.447588 [ 1039 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.449240 [ 42954 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.456406 [ 1051 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.463902 [ 1043 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.498079 [ 42953 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.502261 [ 42954 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.507107 [ 1042 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.510383 [ 1047 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.551820 [ 42953 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.559379 [ 1048 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.609423 [ 42957 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.611706 [ 42956 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.612761 [ 42955 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.617763 [ 1044 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.619061 [ 1045 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.622884 [ 1046 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.642122 [ 2135 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.644837 [ 42954 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.650066 [ 1047 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.652369 [ 1043 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.696568 [ 2135 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.703397 [ 2085 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.704243 [ 1038 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.711693 [ 1014 ] {} 17b824ca-e091-43ec-8864-f1012138c573::all_72_79_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a116c03 17. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1136b9 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 19. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.712323 [ 1014 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {17b824ca-e091-43ec-8864-f1012138c573::all_72_79_1}: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:178: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x000000003a116c03 17. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:208: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a1136b9 18. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 19. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.712368 [ 9253 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.715571 [ 42955 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.722332 [ 1046 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.723120 [ 1040 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.763267 [ 42953 ] {} InterserverIOHTTPHandler: Code: 710. DB::Exception: Failpoint replicated_sends_failpoint is triggered. (FAULT_INJECTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:313: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::WriteBuffer&, int, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039425ded 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9178ff 6. ./build_docker/./src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000001f918d8a 7. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x00000000393f009c 8. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x00000000393e9682 9. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x000000003ac18516 10. ./build_docker/./src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ac19b6a 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003ae1ceca 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:19.776733 [ 1042 ] {} test_ft1f8hxg.data_r2 (17b824ca-e091-43ec-8864-f1012138c573): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::IOException::IOException(String const&, int) @ 0x0000000041205066 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x00000000413eea6e 2. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x0000000041369f45 3. ./build_docker/./base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000004136a8c1 4. ./build_docker/./src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000002669f621 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000266942ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026686242 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000266909b2 9. DB::ReadBuffer::next() @ 0x0000000008e83ccf 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x000000002668a57e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000266702bf 12. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000393fe65f 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038b96a12 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000388eca9f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000388c1bb0 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000388890d4 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038b8fbb0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a2319ac 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000003896422b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038b91b19 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000394bebd7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039741262 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000039742e6c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039752cff 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:05:55.115901 [ 42953 ] {44112930-2731-44f7-9a7b-0320e8b953a6} executeQuery: Code: 53. DB::Exception: CAST AS Tuple can only be performed between tuple types with the same number of elements or from String. Left type: Tuple(Nullable(Nothing), UInt8, UInt8), right type: Tuple(v1 String, v2 Nullable(String)): while executing 'FUNCTION dictGetOrDefault('hashed_array_dictionary'_String :: 1, ('v1', 'v2')_Tuple(String, String) :: 2, _CAST('0'_UInt128, 'UInt128'_String) :: 3, tuple(materialize(_CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String)), intDiv(1_UInt8, __table1.id), intDiv(1_UInt8, __table1.id)) :: 6) -> dictGetOrDefault('hashed_array_dictionary'_String, ('v1', 'v2')_Tuple(String, String), _CAST('0'_UInt128, 'UInt128'_String), tuple(materialize(_CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String)), intDiv(1_UInt8, __table1.id), intDiv(1_UInt8, __table1.id))) Tuple(v1 String, v2 Nullable(String)) : 4'. (TYPE_MISMATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59938) (comment: 02950_dictionary_short_circuit.sql) (query 25, line 82) (in query: -- Fuzzer SELECT dictGetOrDefault('hashed_array_dictionary', ('v1', 'v2'), toUInt128(0), (materialize(toNullable(NULL)), intDiv(1, id), intDiv(1, id))) FROM dictionary_source_table;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::detail::FunctionCast::createTupleWrapper(std::shared_ptr const&, DB::DataTypeTuple const*) const @ 0x000000002c214a04 5. DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000002c20d05f 6. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000002c1c4d41 7. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c1bffa8 8. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x000000002c1beb05 9. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff6953 10. ./build_docker/./src/Interpreters/castColumn.cpp:39: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000336772b9 11. ./build_docker/./src/Interpreters/castColumn.cpp:49: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x000000003367899c 12. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)1>::getDefaultsShortCircuit(DB::PODArray, 63ul, 64ul>&&, std::shared_ptr const&, DB::ColumnWithTypeAndName const&) const @ 0x00000000090b5c65 13. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)1>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000090b46c1 14. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090ac747 15. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 21. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 27. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 09:05:55.128697 [ 42953 ] {} TCPHandler: Code: 53. DB::Exception: CAST AS Tuple can only be performed between tuple types with the same number of elements or from String. Left type: Tuple(Nullable(Nothing), UInt8, UInt8), right type: Tuple(v1 String, v2 Nullable(String)): while executing 'FUNCTION dictGetOrDefault('hashed_array_dictionary'_String :: 1, ('v1', 'v2')_Tuple(String, String) :: 2, _CAST('0'_UInt128, 'UInt128'_String) :: 3, tuple(materialize(_CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String)), intDiv(1_UInt8, __table1.id), intDiv(1_UInt8, __table1.id)) :: 6) -> dictGetOrDefault('hashed_array_dictionary'_String, ('v1', 'v2')_Tuple(String, String), _CAST('0'_UInt128, 'UInt128'_String), tuple(materialize(_CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String)), intDiv(1_UInt8, __table1.id), intDiv(1_UInt8, __table1.id))) Tuple(v1 String, v2 Nullable(String)) : 4'. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::detail::FunctionCast::createTupleWrapper(std::shared_ptr const&, DB::DataTypeTuple const*) const @ 0x000000002c214a04 5. DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000002c20d05f 6. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000002c1c4d41 7. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c1bffa8 8. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x000000002c1beb05 9. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff6953 10. ./build_docker/./src/Interpreters/castColumn.cpp:39: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000336772b9 11. ./build_docker/./src/Interpreters/castColumn.cpp:49: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x000000003367899c 12. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)1>::getDefaultsShortCircuit(DB::PODArray, 63ul, 64ul>&&, std::shared_ptr const&, DB::ColumnWithTypeAndName const&) const @ 0x00000000090b5c65 13. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)1>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000090b46c1 14. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090ac747 15. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 21. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 27. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:05:55.270654 [ 42953 ] {95da89d3-6aa5-43ba-8671-dd5447838d16} executeQuery: Code: 53. DB::Exception: CAST AS Tuple can only be performed between tuple types with the same number of elements or from String. Left type: Tuple(Nullable(Nothing), UInt8, UInt8), right type: Tuple(v1 String, v2 Nullable(String)): while executing 'FUNCTION dictGetOrDefault('hashed_array_dictionary'_String :: 2, ('v1', 'v2')_Tuple(String, String) :: 3, 0_UInt8 :: 4, tuple(intDiv(materialize(_CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String)), __table1.id), intDiv(1_UInt8, __table1.id), intDiv(1_UInt8, __table1.id)) :: 6) -> dictGetOrDefault('hashed_array_dictionary'_String, ('v1', 'v2')_Tuple(String, String), 0_UInt8, tuple(intDiv(materialize(_CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String)), __table1.id), intDiv(1_UInt8, __table1.id), intDiv(1_UInt8, __table1.id))) Tuple(v1 String, v2 Nullable(String)) : 5'. (TYPE_MISMATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59938) (comment: 02950_dictionary_short_circuit.sql) (query 26, line 84) (in query: SELECT materialize(materialize(toLowCardinality(15))), dictGetOrDefault('hashed_array_dictionary', ('v1', 'v2'), 0, (intDiv(materialize(NULL), id), intDiv(1, id), intDiv(1, id))) FROM dictionary_source_table;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::detail::FunctionCast::createTupleWrapper(std::shared_ptr const&, DB::DataTypeTuple const*) const @ 0x000000002c214a04 5. DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000002c20d05f 6. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000002c1c4d41 7. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c1bffa8 8. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x000000002c1beb05 9. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff6953 10. ./build_docker/./src/Interpreters/castColumn.cpp:39: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000336772b9 11. ./build_docker/./src/Interpreters/castColumn.cpp:49: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x000000003367899c 12. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)1>::getDefaultsShortCircuit(DB::PODArray, 63ul, 64ul>&&, std::shared_ptr const&, DB::ColumnWithTypeAndName const&) const @ 0x00000000090b5c65 13. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)1>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000090b46c1 14. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090ac747 15. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 21. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 27. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 09:05:55.283216 [ 42953 ] {} TCPHandler: Code: 53. DB::Exception: CAST AS Tuple can only be performed between tuple types with the same number of elements or from String. Left type: Tuple(Nullable(Nothing), UInt8, UInt8), right type: Tuple(v1 String, v2 Nullable(String)): while executing 'FUNCTION dictGetOrDefault('hashed_array_dictionary'_String :: 2, ('v1', 'v2')_Tuple(String, String) :: 3, 0_UInt8 :: 4, tuple(intDiv(materialize(_CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String)), __table1.id), intDiv(1_UInt8, __table1.id), intDiv(1_UInt8, __table1.id)) :: 6) -> dictGetOrDefault('hashed_array_dictionary'_String, ('v1', 'v2')_Tuple(String, String), 0_UInt8, tuple(intDiv(materialize(_CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String)), __table1.id), intDiv(1_UInt8, __table1.id), intDiv(1_UInt8, __table1.id))) Tuple(v1 String, v2 Nullable(String)) : 5'. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::detail::FunctionCast::createTupleWrapper(std::shared_ptr const&, DB::DataTypeTuple const*) const @ 0x000000002c214a04 5. DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000002c20d05f 6. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000002c1c4d41 7. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c1bffa8 8. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x000000002c1beb05 9. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff6953 10. ./build_docker/./src/Interpreters/castColumn.cpp:39: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000336772b9 11. ./build_docker/./src/Interpreters/castColumn.cpp:49: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x000000003367899c 12. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)1>::getDefaultsShortCircuit(DB::PODArray, 63ul, 64ul>&&, std::shared_ptr const&, DB::ColumnWithTypeAndName const&) const @ 0x00000000090b5c65 13. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)1>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000090b46c1 14. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090ac747 15. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 21. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 27. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:05:55.403157 [ 42953 ] {edf07f1f-e266-4557-b527-c1cad5d00917} executeQuery: Code: 53. DB::Exception: CAST AS Tuple can only be performed between tuple types with the same number of elements or from String. Left type: Tuple(Nullable(Nothing), UInt8, UInt8), right type: Tuple(v1 String, v2 Nullable(String)): while executing 'FUNCTION dictGetOrDefault('hashed_array_dictionary'_String :: 1, ('v1', 'v2')_Tuple(String, String) :: 2, 0_UInt8 :: 3, tuple(_CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String), intDiv(1_UInt8, __table1.id), intDiv(1_UInt8, __table1.id)) :: 6) -> dictGetOrDefault('hashed_array_dictionary'_String, ('v1', 'v2')_Tuple(String, String), 0_UInt8, tuple(_CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String), intDiv(1_UInt8, __table1.id), intDiv(1_UInt8, __table1.id))) Tuple(v1 String, v2 Nullable(String)) : 0'. (TYPE_MISMATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59938) (comment: 02950_dictionary_short_circuit.sql) (query 27, line 85) (in query: SELECT dictGetOrDefault('hashed_array_dictionary', ('v1', 'v2'), 0, (toNullable(NULL), intDiv(1, id), intDiv(1, id))) FROM dictionary_source_table;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::detail::FunctionCast::createTupleWrapper(std::shared_ptr const&, DB::DataTypeTuple const*) const @ 0x000000002c214a04 5. DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000002c20d05f 6. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000002c1c4d41 7. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c1bffa8 8. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x000000002c1beb05 9. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff6953 10. ./build_docker/./src/Interpreters/castColumn.cpp:39: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000336772b9 11. ./build_docker/./src/Interpreters/castColumn.cpp:49: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x000000003367899c 12. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)1>::getDefaultsShortCircuit(DB::PODArray, 63ul, 64ul>&&, std::shared_ptr const&, DB::ColumnWithTypeAndName const&) const @ 0x00000000090b5c65 13. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)1>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000090b46c1 14. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090ac747 15. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 21. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 27. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 09:05:55.414258 [ 42953 ] {} TCPHandler: Code: 53. DB::Exception: CAST AS Tuple can only be performed between tuple types with the same number of elements or from String. Left type: Tuple(Nullable(Nothing), UInt8, UInt8), right type: Tuple(v1 String, v2 Nullable(String)): while executing 'FUNCTION dictGetOrDefault('hashed_array_dictionary'_String :: 1, ('v1', 'v2')_Tuple(String, String) :: 2, 0_UInt8 :: 3, tuple(_CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String), intDiv(1_UInt8, __table1.id), intDiv(1_UInt8, __table1.id)) :: 6) -> dictGetOrDefault('hashed_array_dictionary'_String, ('v1', 'v2')_Tuple(String, String), 0_UInt8, tuple(_CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String), intDiv(1_UInt8, __table1.id), intDiv(1_UInt8, __table1.id))) Tuple(v1 String, v2 Nullable(String)) : 0'. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::detail::FunctionCast::createTupleWrapper(std::shared_ptr const&, DB::DataTypeTuple const*) const @ 0x000000002c214a04 5. DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000002c20d05f 6. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000002c1c4d41 7. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c1bffa8 8. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x000000002c1beb05 9. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff6953 10. ./build_docker/./src/Interpreters/castColumn.cpp:39: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000336772b9 11. ./build_docker/./src/Interpreters/castColumn.cpp:49: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x000000003367899c 12. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)1>::getDefaultsShortCircuit(DB::PODArray, 63ul, 64ul>&&, std::shared_ptr const&, DB::ColumnWithTypeAndName const&) const @ 0x00000000090b5c65 13. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)1>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000090b46c1 14. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090ac747 15. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 21. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 27. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:06:03.733513 [ 42953 ] {13c632f9-b39f-4129-82cb-3c39f8c22e03} executeQuery: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION dictGetOrDefault('regexp_dict'_String :: 1, 'name'_String :: 2, concat('/tclwebkit'_String, toString(__table1.number)) :: 5, intDiv(1_UInt8, __table1.number) :: 6) -> dictGetOrDefault('regexp_dict'_String, 'name'_String, concat('/tclwebkit'_String, toString(__table1.number)), intDiv(1_UInt8, __table1.number)) String : 0'. (ILLEGAL_DIVISION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59938) (comment: 02950_dictionary_short_circuit.sql) (query 87, line 267) (in query: -- Fuzzer SELECT dictGetOrDefault('regexp_dict', 'name', concat('/tclwebkit', toString(number)), intDiv(1, number)) FROM numbers(2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. void DB::impl_::BinaryOperation, char8_t>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned long const*, char8_t*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000011674889 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000011cfb00d 6. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeNumber>(auto const&, auto const&) const @ 0x0000000011cf9cb0 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000011cf1f69 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000011cef466 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000011ce5ef2 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011ce04ad 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011cdd76d 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff69df 17. ./build_docker/./src/Columns/ColumnFunction.cpp:372: DB::ColumnFunction::reduce() const @ 0x0000000037416960 18. ./build_docker/./src/Columns/MaskOperations.cpp:279: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x00000000381403fc 19. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)1>::getDefaultsShortCircuit(DB::PODArray, 63ul, 64ul>&&, std::shared_ptr const&, DB::ColumnWithTypeAndName const&) const @ 0x00000000090b59fd 20. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)1>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000090b3f33 21. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090ac747 22. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 26. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 27. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 28. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 29. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 2025.06.13 09:06:03.746010 [ 42953 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION dictGetOrDefault('regexp_dict'_String :: 1, 'name'_String :: 2, concat('/tclwebkit'_String, toString(__table1.number)) :: 5, intDiv(1_UInt8, __table1.number) :: 6) -> dictGetOrDefault('regexp_dict'_String, 'name'_String, concat('/tclwebkit'_String, toString(__table1.number)), intDiv(1_UInt8, __table1.number)) String : 0'. (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. void DB::impl_::BinaryOperation, char8_t>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned long const*, char8_t*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000011674889 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000011cfb00d 6. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeNumber>(auto const&, auto const&) const @ 0x0000000011cf9cb0 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000011cf1f69 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000011cef466 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000011ce5ef2 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011ce04ad 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011cdd76d 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 16. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff69df 17. ./build_docker/./src/Columns/ColumnFunction.cpp:372: DB::ColumnFunction::reduce() const @ 0x0000000037416960 18. ./build_docker/./src/Columns/MaskOperations.cpp:279: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x00000000381403fc 19. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)1>::getDefaultsShortCircuit(DB::PODArray, 63ul, 64ul>&&, std::shared_ptr const&, DB::ColumnWithTypeAndName const&) const @ 0x00000000090b59fd 20. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)1>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000090b3f33 21. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090ac747 22. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 26. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 27. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 28. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 29. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:06:12.023294 [ 410 ] {} CgroupsReader: Cannot find 'kernel' in '/sys/fs/cgroup/memory.stat' (skipped 5903 similar messages) 2025.06.13 09:07:16.009316 [ 43342 ] {8fb747d2-2f83-4e93-941c-7106e3d4f286} executeQuery: Code: 354. DB::Exception: inflate failed: data error: While reading from: /var/lib/clickhouse/user_files/corrupted_file.tsv.xx: (while reading header): (in file/uri /var/lib/clickhouse/user_files/corrupted_file.tsv.xx): While executing TabSeparatedRowInputFormat: While executing File. (ZLIB_INFLATE_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52608) (comment: 02724_decompress_filename_exception.sh) (query 1, line 1) (in query: SELECT * FROM file('/var/lib/clickhouse/user_files/corrupted_file.tsv.xx', 'TSV', 'c UInt32', 'gzip')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String&&) @ 0x000000001b1d284d 4. ./build_docker/./src/IO/ZlibInflatingReadBuffer.cpp:111: DB::ZlibInflatingReadBuffer::nextImpl() @ 0x000000001ff64ecc 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/PeekableReadBuffer.cpp:179: DB::PeekableReadBuffer::nextImpl() @ 0x000000001f8f1802 7. DB::ReadBuffer::next() @ 0x0000000008e83ccf 8. ./src/IO/ReadBuffer.h:96: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x000000003b308ca3 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:97: DB::IRowInputFormat::read() @ 0x000000003b27428b 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b108bd9 11. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 12. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 17. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000038415cf2 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 09:07:16.030847 [ 43342 ] {} TCPHandler: Code: 354. DB::Exception: inflate failed: data error: While reading from: /var/lib/clickhouse/user_files/corrupted_file.tsv.xx: (while reading header): (in file/uri /var/lib/clickhouse/user_files/corrupted_file.tsv.xx): While executing TabSeparatedRowInputFormat: While executing File. (ZLIB_INFLATE_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String&&) @ 0x000000001b1d284d 4. ./build_docker/./src/IO/ZlibInflatingReadBuffer.cpp:111: DB::ZlibInflatingReadBuffer::nextImpl() @ 0x000000001ff64ecc 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/PeekableReadBuffer.cpp:179: DB::PeekableReadBuffer::nextImpl() @ 0x000000001f8f1802 7. DB::ReadBuffer::next() @ 0x0000000008e83ccf 8. ./src/IO/ReadBuffer.h:96: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x000000003b308ca3 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:97: DB::IRowInputFormat::read() @ 0x000000003b27428b 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b108bd9 11. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 12. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 17. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000038415cf2 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:07:16.969718 [ 43342 ] {b73e920d-91ea-4581-830d-a1acbf58ac19} executeQuery: Code: 354. DB::Exception: inflate failed: data error: While reading from: /var/lib/clickhouse/user_files/corrupted_file.tsv.xx: (while reading header): (in file/uri /var/lib/clickhouse/user_files/corrupted_file.tsv.xx): While executing TabSeparatedRowInputFormat: While executing File. (ZLIB_INFLATE_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52618) (comment: 02724_decompress_filename_exception.sh) (query 1, line 1) (in query: SELECT * FROM file('/var/lib/clickhouse/user_files/corrupted_file.tsv.xx', 'TSV', 'c UInt32', 'deflate')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String&&) @ 0x000000001b1d284d 4. ./build_docker/./src/IO/ZlibInflatingReadBuffer.cpp:111: DB::ZlibInflatingReadBuffer::nextImpl() @ 0x000000001ff64ecc 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/PeekableReadBuffer.cpp:179: DB::PeekableReadBuffer::nextImpl() @ 0x000000001f8f1802 7. DB::ReadBuffer::next() @ 0x0000000008e83ccf 8. ./src/IO/ReadBuffer.h:96: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x000000003b308ca3 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:97: DB::IRowInputFormat::read() @ 0x000000003b27428b 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b108bd9 11. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 12. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 17. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000038415cf2 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 09:07:16.994828 [ 43342 ] {} TCPHandler: Code: 354. DB::Exception: inflate failed: data error: While reading from: /var/lib/clickhouse/user_files/corrupted_file.tsv.xx: (while reading header): (in file/uri /var/lib/clickhouse/user_files/corrupted_file.tsv.xx): While executing TabSeparatedRowInputFormat: While executing File. (ZLIB_INFLATE_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String&&) @ 0x000000001b1d284d 4. ./build_docker/./src/IO/ZlibInflatingReadBuffer.cpp:111: DB::ZlibInflatingReadBuffer::nextImpl() @ 0x000000001ff64ecc 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/PeekableReadBuffer.cpp:179: DB::PeekableReadBuffer::nextImpl() @ 0x000000001f8f1802 7. DB::ReadBuffer::next() @ 0x0000000008e83ccf 8. ./src/IO/ReadBuffer.h:96: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x000000003b308ca3 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:97: DB::IRowInputFormat::read() @ 0x000000003b27428b 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b108bd9 11. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 12. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 17. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000038415cf2 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:07:18.124593 [ 43342 ] {61370942-2b6d-4f07-b426-47efd3f659a1} executeQuery: Code: 448. DB::Exception: brotli decode error: While reading from: /var/lib/clickhouse/user_files/corrupted_file.tsv.xx: (while reading header): (in file/uri /var/lib/clickhouse/user_files/corrupted_file.tsv.xx): While executing TabSeparatedRowInputFormat: While executing File. (BROTLI_READ_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52620) (comment: 02724_decompress_filename_exception.sh) (query 1, line 1) (in query: SELECT * FROM file('/var/lib/clickhouse/user_files/corrupted_file.tsv.xx', 'TSV', 'c UInt32', 'br')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/IO/BrotliReadBuffer.cpp:94: DB::BrotliReadBuffer::nextImpl() @ 0x000000001ff6dcba 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/PeekableReadBuffer.cpp:179: DB::PeekableReadBuffer::nextImpl() @ 0x000000001f8f1802 7. DB::ReadBuffer::next() @ 0x0000000008e83ccf 8. ./src/IO/ReadBuffer.h:96: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x000000003b308ca3 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:97: DB::IRowInputFormat::read() @ 0x000000003b27428b 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b108bd9 11. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 12. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 17. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000038415cf2 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 09:07:18.141433 [ 43342 ] {} TCPHandler: Code: 448. DB::Exception: brotli decode error: While reading from: /var/lib/clickhouse/user_files/corrupted_file.tsv.xx: (while reading header): (in file/uri /var/lib/clickhouse/user_files/corrupted_file.tsv.xx): While executing TabSeparatedRowInputFormat: While executing File. (BROTLI_READ_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/IO/BrotliReadBuffer.cpp:94: DB::BrotliReadBuffer::nextImpl() @ 0x000000001ff6dcba 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/PeekableReadBuffer.cpp:179: DB::PeekableReadBuffer::nextImpl() @ 0x000000001f8f1802 7. DB::ReadBuffer::next() @ 0x0000000008e83ccf 8. ./src/IO/ReadBuffer.h:96: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x000000003b308ca3 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:97: DB::IRowInputFormat::read() @ 0x000000003b27428b 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b108bd9 11. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 12. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 17. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000038415cf2 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:07:19.352132 [ 43342 ] {4cc3c581-2b4a-4d62-af5c-a283337b164b} executeQuery: Code: 554. DB::Exception: lzma_stream_decoder failed: error code: error code LZMA_FORMAT_ERROR; lzma version: 5.3.1alpha: While reading from: /var/lib/clickhouse/user_files/corrupted_file.tsv.xx: (while reading header): (in file/uri /var/lib/clickhouse/user_files/corrupted_file.tsv.xx): While executing TabSeparatedRowInputFormat: While executing File. (LZMA_STREAM_DECODER_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52622) (comment: 02724_decompress_filename_exception.sh) (query 1, line 1) (in query: SELECT * FROM file('/var/lib/clickhouse/user_files/corrupted_file.tsv.xx', 'TSV', 'c UInt32', 'xz')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, lzma_ret&, char const (&) [11], String&&) @ 0x000000001ff67557 4. ./build_docker/./src/IO/LZMAInflatingReadBuffer.cpp:88: DB::LZMAInflatingReadBuffer::nextImpl() @ 0x000000001ff671c5 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/PeekableReadBuffer.cpp:179: DB::PeekableReadBuffer::nextImpl() @ 0x000000001f8f1802 7. DB::ReadBuffer::next() @ 0x0000000008e83ccf 8. ./src/IO/ReadBuffer.h:96: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x000000003b308ca3 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:97: DB::IRowInputFormat::read() @ 0x000000003b27428b 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b108bd9 11. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 12. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 17. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000038415cf2 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 09:07:19.373084 [ 43342 ] {} TCPHandler: Code: 554. DB::Exception: lzma_stream_decoder failed: error code: error code LZMA_FORMAT_ERROR; lzma version: 5.3.1alpha: While reading from: /var/lib/clickhouse/user_files/corrupted_file.tsv.xx: (while reading header): (in file/uri /var/lib/clickhouse/user_files/corrupted_file.tsv.xx): While executing TabSeparatedRowInputFormat: While executing File. (LZMA_STREAM_DECODER_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, lzma_ret&, char const (&) [11], String&&) @ 0x000000001ff67557 4. ./build_docker/./src/IO/LZMAInflatingReadBuffer.cpp:88: DB::LZMAInflatingReadBuffer::nextImpl() @ 0x000000001ff671c5 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/PeekableReadBuffer.cpp:179: DB::PeekableReadBuffer::nextImpl() @ 0x000000001f8f1802 7. DB::ReadBuffer::next() @ 0x0000000008e83ccf 8. ./src/IO/ReadBuffer.h:96: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x000000003b308ca3 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:97: DB::IRowInputFormat::read() @ 0x000000003b27428b 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b108bd9 11. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 12. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 17. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000038415cf2 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:07:20.580195 [ 43342 ] {1547020f-542e-4915-a5e6-f017d3370d39} executeQuery: Code: 561. DB::Exception: ZSTD stream decoding failed: error 'Unknown frame descriptor'; ZSTD version: 1.5.7: While reading from: /var/lib/clickhouse/user_files/corrupted_file.tsv.xx: (while reading header): (in file/uri /var/lib/clickhouse/user_files/corrupted_file.tsv.xx): While executing TabSeparatedRowInputFormat: While executing File. (ZSTD_DECODER_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52638) (comment: 02724_decompress_filename_exception.sh) (query 1, line 1) (in query: SELECT * FROM file('/var/lib/clickhouse/user_files/corrupted_file.tsv.xx', 'TSV', 'c UInt32', 'zstd')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, char const (&) [6], String&&) @ 0x000000001f9056df 4. ./build_docker/./src/IO/ZstdInflatingReadBuffer.cpp:63: DB::ZstdInflatingReadBuffer::nextImpl() @ 0x000000001f90530c 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/PeekableReadBuffer.cpp:179: DB::PeekableReadBuffer::nextImpl() @ 0x000000001f8f1802 7. DB::ReadBuffer::next() @ 0x0000000008e83ccf 8. ./src/IO/ReadBuffer.h:96: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x000000003b308ca3 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:97: DB::IRowInputFormat::read() @ 0x000000003b27428b 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b108bd9 11. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 12. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 17. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000038415cf2 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 09:07:20.600295 [ 43342 ] {} TCPHandler: Code: 561. DB::Exception: ZSTD stream decoding failed: error 'Unknown frame descriptor'; ZSTD version: 1.5.7: While reading from: /var/lib/clickhouse/user_files/corrupted_file.tsv.xx: (while reading header): (in file/uri /var/lib/clickhouse/user_files/corrupted_file.tsv.xx): While executing TabSeparatedRowInputFormat: While executing File. (ZSTD_DECODER_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, char const (&) [6], String&&) @ 0x000000001f9056df 4. ./build_docker/./src/IO/ZstdInflatingReadBuffer.cpp:63: DB::ZstdInflatingReadBuffer::nextImpl() @ 0x000000001f90530c 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/PeekableReadBuffer.cpp:179: DB::PeekableReadBuffer::nextImpl() @ 0x000000001f8f1802 7. DB::ReadBuffer::next() @ 0x0000000008e83ccf 8. ./src/IO/ReadBuffer.h:96: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x000000003b308ca3 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:97: DB::IRowInputFormat::read() @ 0x000000003b27428b 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b108bd9 11. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 12. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 17. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000038415cf2 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:07:21.733466 [ 43342 ] {ed571cb3-b741-4c97-9bc1-4cbe5ea83dcb} executeQuery: Code: 618. DB::Exception: LZ4 decompression failed. LZ4F version: 100. Error: ERROR_frameType_unknown: While reading from: /var/lib/clickhouse/user_files/corrupted_file.tsv.xx: (while reading header): (in file/uri /var/lib/clickhouse/user_files/corrupted_file.tsv.xx): While executing TabSeparatedRowInputFormat: While executing File. (LZ4_DECODER_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52648) (comment: 02724_decompress_filename_exception.sh) (query 1, line 1) (in query: SELECT * FROM file('/var/lib/clickhouse/user_files/corrupted_file.tsv.xx', 'TSV', 'c UInt32', 'lz4')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, int&&, char const*&&, String&&) @ 0x000000001ff6fcf7 4. ./build_docker/./src/IO/Lz4InflatingReadBuffer.cpp:74: DB::Lz4InflatingReadBuffer::nextImpl() @ 0x000000001ff6f965 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/PeekableReadBuffer.cpp:179: DB::PeekableReadBuffer::nextImpl() @ 0x000000001f8f1802 7. DB::ReadBuffer::next() @ 0x0000000008e83ccf 8. ./src/IO/ReadBuffer.h:96: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x000000003b308ca3 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:97: DB::IRowInputFormat::read() @ 0x000000003b27428b 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b108bd9 11. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 12. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 17. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000038415cf2 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 09:07:21.751763 [ 43342 ] {} TCPHandler: Code: 618. DB::Exception: LZ4 decompression failed. LZ4F version: 100. Error: ERROR_frameType_unknown: While reading from: /var/lib/clickhouse/user_files/corrupted_file.tsv.xx: (while reading header): (in file/uri /var/lib/clickhouse/user_files/corrupted_file.tsv.xx): While executing TabSeparatedRowInputFormat: While executing File. (LZ4_DECODER_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, int&&, char const*&&, String&&) @ 0x000000001ff6fcf7 4. ./build_docker/./src/IO/Lz4InflatingReadBuffer.cpp:74: DB::Lz4InflatingReadBuffer::nextImpl() @ 0x000000001ff6f965 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/PeekableReadBuffer.cpp:179: DB::PeekableReadBuffer::nextImpl() @ 0x000000001f8f1802 7. DB::ReadBuffer::next() @ 0x0000000008e83ccf 8. ./src/IO/ReadBuffer.h:96: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x000000003b308ca3 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:97: DB::IRowInputFormat::read() @ 0x000000003b27428b 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b108bd9 11. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 12. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 17. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000038415cf2 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:07:22.951628 [ 43342 ] {4e7b4589-b3f1-44de-9e35-ec557fcd1690} executeQuery: Code: 594. DB::Exception: bzip2 stream decoder failed: error code: -5: While reading from: /var/lib/clickhouse/user_files/corrupted_file.tsv.xx: (while reading header): (in file/uri /var/lib/clickhouse/user_files/corrupted_file.tsv.xx): While executing TabSeparatedRowInputFormat: While executing File. (BZIP2_STREAM_DECODER_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52654) (comment: 02724_decompress_filename_exception.sh) (query 1, line 1) (in query: SELECT * FROM file('/var/lib/clickhouse/user_files/corrupted_file.tsv.xx', 'TSV', 'c UInt32', 'bz2')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, int&, String&&) @ 0x000000001ff6c06d 4. ./build_docker/./src/IO/Bzip2ReadBuffer.cpp:120: DB::Bzip2ReadBuffer::nextImpl() @ 0x000000001ff6b3bc 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/PeekableReadBuffer.cpp:179: DB::PeekableReadBuffer::nextImpl() @ 0x000000001f8f1802 7. DB::ReadBuffer::next() @ 0x0000000008e83ccf 8. ./src/IO/ReadBuffer.h:96: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x000000003b308ca3 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:97: DB::IRowInputFormat::read() @ 0x000000003b27428b 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b108bd9 11. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 12. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 17. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000038415cf2 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 09:07:22.972781 [ 43342 ] {} TCPHandler: Code: 594. DB::Exception: bzip2 stream decoder failed: error code: -5: While reading from: /var/lib/clickhouse/user_files/corrupted_file.tsv.xx: (while reading header): (in file/uri /var/lib/clickhouse/user_files/corrupted_file.tsv.xx): While executing TabSeparatedRowInputFormat: While executing File. (BZIP2_STREAM_DECODER_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, int&, String&&) @ 0x000000001ff6c06d 4. ./build_docker/./src/IO/Bzip2ReadBuffer.cpp:120: DB::Bzip2ReadBuffer::nextImpl() @ 0x000000001ff6b3bc 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/PeekableReadBuffer.cpp:179: DB::PeekableReadBuffer::nextImpl() @ 0x000000001f8f1802 7. DB::ReadBuffer::next() @ 0x0000000008e83ccf 8. ./src/IO/ReadBuffer.h:96: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x000000003b308ca3 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:97: DB::IRowInputFormat::read() @ 0x000000003b27428b 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b108bd9 11. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 12. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 17. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000038415cf2 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:07:24.136105 [ 43342 ] {14aef622-6724-41f4-b008-ca044508adc2} executeQuery: Code: 638. DB::Exception: hadoop snappy decode error: TOO_LARGE_COMPRESSED_BLOCK: While reading from: /var/lib/clickhouse/user_files/corrupted_file.tsv.xx: (while reading header): (in file/uri /var/lib/clickhouse/user_files/corrupted_file.tsv.xx): While executing TabSeparatedRowInputFormat: While executing File. (SNAPPY_UNCOMPRESS_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39664) (comment: 02724_decompress_filename_exception.sh) (query 1, line 1) (in query: SELECT * FROM file('/var/lib/clickhouse/user_files/corrupted_file.tsv.xx', 'TSV', 'c UInt32', 'snappy')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/IO/HadoopSnappyReadBuffer.cpp:229: DB::HadoopSnappyReadBuffer::nextImpl() @ 0x000000001ff73a8d 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/PeekableReadBuffer.cpp:179: DB::PeekableReadBuffer::nextImpl() @ 0x000000001f8f1802 7. DB::ReadBuffer::next() @ 0x0000000008e83ccf 8. ./src/IO/ReadBuffer.h:96: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x000000003b308ca3 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:97: DB::IRowInputFormat::read() @ 0x000000003b27428b 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b108bd9 11. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 12. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 17. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000038415cf2 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 2025.06.13 09:07:24.155079 [ 43342 ] {} TCPHandler: Code: 638. DB::Exception: hadoop snappy decode error: TOO_LARGE_COMPRESSED_BLOCK: While reading from: /var/lib/clickhouse/user_files/corrupted_file.tsv.xx: (while reading header): (in file/uri /var/lib/clickhouse/user_files/corrupted_file.tsv.xx): While executing TabSeparatedRowInputFormat: While executing File. (SNAPPY_UNCOMPRESS_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/IO/HadoopSnappyReadBuffer.cpp:229: DB::HadoopSnappyReadBuffer::nextImpl() @ 0x000000001ff73a8d 5. DB::ReadBuffer::next() @ 0x0000000008e83ccf 6. ./build_docker/./src/IO/PeekableReadBuffer.cpp:179: DB::PeekableReadBuffer::nextImpl() @ 0x000000001f8f1802 7. DB::ReadBuffer::next() @ 0x0000000008e83ccf 8. ./src/IO/ReadBuffer.h:96: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x000000003b308ca3 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:97: DB::IRowInputFormat::read() @ 0x000000003b27428b 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b108bd9 11. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 12. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 17. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x0000000038415cf2 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:07:43.261525 [ 37786 ] {cdaf2e77-0100-43b2-ac93-a210d4949307} ExternalDictionariesLoader: Could not update external dictionary 'f8e41dba-7a4a-458b-bb30-97fe60407988', leaving the previous version: Code: 489. DB::Exception: Cannot parse abcde for data type Int64, Reason is: Code: 632. DB::Exception: Unexpected data 'abcde' after parsed Number value '0'. (UNEXPECTED_DATA_AFTER_PARSED_VALUE) (version 25.3.3.20286.altinityantalya (altinity build)). (INCORRECT_DICTIONARY_DEFINITION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x00000000266069d7 4. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:92: DB::(anonymous namespace)::parseStringToField(String const&, std::shared_ptr) @ 0x000000002719673d 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:242: DB::RegExpTreeDictionary::initRegexNodes(DB::Block&) @ 0x000000002718f0e6 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:330: DB::RegExpTreeDictionary::loadData() @ 0x000000002719811b 7. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:432: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x000000002719d793 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x00000000271b87f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 10. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 11. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 13. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoadOrReload(String const&, std::chrono::duration>) @ 0x00000000327db05d 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1397: std::shared_ptr DB::ExternalLoader::loadOrReload, void>(String const&) const @ 0x00000000327d4702 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:108: DB::ExternalDictionariesLoader::reloadDictionary(String const&, std::shared_ptr) const @ 0x00000000327c1265 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:613: DB::InterpreterSystemQuery::execute() @ 0x00000000337e14a7 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:07:43.268915 [ 43342 ] {cdaf2e77-0100-43b2-ac93-a210d4949307} executeQuery: Code: 489. DB::Exception: Cannot parse abcde for data type Int64, Reason is: Code: 632. DB::Exception: Unexpected data 'abcde' after parsed Number value '0'. (UNEXPECTED_DATA_AFTER_PARSED_VALUE) (version 25.3.3.20286.altinityantalya (altinity build)). (INCORRECT_DICTIONARY_DEFINITION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46660) (comment: 02504_regexp_dictionary_yaml_source.sh) (query 1, line 2) (in query: system reload dictionary regexp_dict1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x00000000266069d7 4. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:92: DB::(anonymous namespace)::parseStringToField(String const&, std::shared_ptr) @ 0x000000002719673d 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:242: DB::RegExpTreeDictionary::initRegexNodes(DB::Block&) @ 0x000000002718f0e6 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:330: DB::RegExpTreeDictionary::loadData() @ 0x000000002719811b 7. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:432: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x000000002719d793 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x00000000271b87f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 10. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 11. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 13. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:07:43.278309 [ 43342 ] {} TCPHandler: Code: 489. DB::Exception: Cannot parse abcde for data type Int64, Reason is: Code: 632. DB::Exception: Unexpected data 'abcde' after parsed Number value '0'. (UNEXPECTED_DATA_AFTER_PARSED_VALUE) (version 25.3.3.20286.altinityantalya (altinity build)). (INCORRECT_DICTIONARY_DEFINITION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x00000000266069d7 4. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:92: DB::(anonymous namespace)::parseStringToField(String const&, std::shared_ptr) @ 0x000000002719673d 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:242: DB::RegExpTreeDictionary::initRegexNodes(DB::Block&) @ 0x000000002718f0e6 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:330: DB::RegExpTreeDictionary::loadData() @ 0x000000002719811b 7. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:432: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x000000002719d793 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x00000000271b87f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 10. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 11. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 13. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoadOrReload(String const&, std::chrono::duration>) @ 0x00000000327db05d 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1397: std::shared_ptr DB::ExternalLoader::loadOrReload, void>(String const&) const @ 0x00000000327d4702 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:108: DB::ExternalDictionariesLoader::reloadDictionary(String const&, std::shared_ptr) const @ 0x00000000327c1265 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:613: DB::InterpreterSystemQuery::execute() @ 0x00000000337e14a7 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 09:07:44.327474 [ 34128 ] {a1500c69-9a6f-48dc-91dc-86f16b8a2fc4} ExternalDictionariesLoader: Could not update external dictionary 'f8e41dba-7a4a-458b-bb30-97fe60407988', leaving the previous version: Code: 318. DB::Exception: `regexp` should be a String. (INVALID_CONFIG_PARAMETER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Dictionaries/YAMLRegExpTreeDictionarySource.cpp:236: DB::parseMatchNode(unsigned long, unsigned long&, YAML::Node const&, DB::ResultColumns&, String const&, DB::DictionaryStructure const&) @ 0x0000000026fd9444 5. ./build_docker/./src/Dictionaries/YAMLRegExpTreeDictionarySource.cpp:263: DB::parseMatchList(unsigned long, unsigned long&, YAML::Node const&, DB::ResultColumns&, String const&, DB::DictionaryStructure const&) @ 0x0000000026fdacb0 6. ./build_docker/./src/Dictionaries/YAMLRegExpTreeDictionarySource.cpp:271: DB::parseYAMLAsRegExpTree(YAML::Node const&, String const&, DB::DictionaryStructure const&) @ 0x0000000026fdb9c5 7. ./build_docker/./src/Dictionaries/YAMLRegExpTreeDictionarySource.cpp:315: DB::YAMLRegExpTreeDictionarySource::loadAll() @ 0x0000000026fdfda9 8. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:323: DB::RegExpTreeDictionary::loadData() @ 0x0000000027197fa1 9. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:432: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x000000002719d793 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x00000000271b87f8 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 12. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 13. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 14. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 15. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoadOrReload(String const&, std::chrono::duration>) @ 0x00000000327db05d 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1397: std::shared_ptr DB::ExternalLoader::loadOrReload, void>(String const&) const @ 0x00000000327d4702 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:108: DB::ExternalDictionariesLoader::reloadDictionary(String const&, std::shared_ptr) const @ 0x00000000327c1265 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:613: DB::InterpreterSystemQuery::execute() @ 0x00000000337e14a7 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:07:44.333739 [ 43342 ] {a1500c69-9a6f-48dc-91dc-86f16b8a2fc4} executeQuery: Code: 318. DB::Exception: `regexp` should be a String. (INVALID_CONFIG_PARAMETER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54022) (comment: 02504_regexp_dictionary_yaml_source.sh) (query 1, line 2) (in query: system reload dictionary regexp_dict1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Dictionaries/YAMLRegExpTreeDictionarySource.cpp:236: DB::parseMatchNode(unsigned long, unsigned long&, YAML::Node const&, DB::ResultColumns&, String const&, DB::DictionaryStructure const&) @ 0x0000000026fd9444 5. ./build_docker/./src/Dictionaries/YAMLRegExpTreeDictionarySource.cpp:263: DB::parseMatchList(unsigned long, unsigned long&, YAML::Node const&, DB::ResultColumns&, String const&, DB::DictionaryStructure const&) @ 0x0000000026fdacb0 6. ./build_docker/./src/Dictionaries/YAMLRegExpTreeDictionarySource.cpp:271: DB::parseYAMLAsRegExpTree(YAML::Node const&, String const&, DB::DictionaryStructure const&) @ 0x0000000026fdb9c5 7. ./build_docker/./src/Dictionaries/YAMLRegExpTreeDictionarySource.cpp:315: DB::YAMLRegExpTreeDictionarySource::loadAll() @ 0x0000000026fdfda9 8. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:323: DB::RegExpTreeDictionary::loadData() @ 0x0000000027197fa1 9. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:432: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x000000002719d793 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x00000000271b87f8 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 12. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 13. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 14. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 15. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 09:07:44.342943 [ 43342 ] {} TCPHandler: Code: 318. DB::Exception: `regexp` should be a String. (INVALID_CONFIG_PARAMETER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Dictionaries/YAMLRegExpTreeDictionarySource.cpp:236: DB::parseMatchNode(unsigned long, unsigned long&, YAML::Node const&, DB::ResultColumns&, String const&, DB::DictionaryStructure const&) @ 0x0000000026fd9444 5. ./build_docker/./src/Dictionaries/YAMLRegExpTreeDictionarySource.cpp:263: DB::parseMatchList(unsigned long, unsigned long&, YAML::Node const&, DB::ResultColumns&, String const&, DB::DictionaryStructure const&) @ 0x0000000026fdacb0 6. ./build_docker/./src/Dictionaries/YAMLRegExpTreeDictionarySource.cpp:271: DB::parseYAMLAsRegExpTree(YAML::Node const&, String const&, DB::DictionaryStructure const&) @ 0x0000000026fdb9c5 7. ./build_docker/./src/Dictionaries/YAMLRegExpTreeDictionarySource.cpp:315: DB::YAMLRegExpTreeDictionarySource::loadAll() @ 0x0000000026fdfda9 8. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:323: DB::RegExpTreeDictionary::loadData() @ 0x0000000027197fa1 9. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:432: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x000000002719d793 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x00000000271b87f8 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 12. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 13. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 14. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 15. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoadOrReload(String const&, std::chrono::duration>) @ 0x00000000327db05d 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1397: std::shared_ptr DB::ExternalLoader::loadOrReload, void>(String const&) const @ 0x00000000327d4702 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:108: DB::ExternalDictionariesLoader::reloadDictionary(String const&, std::shared_ptr) const @ 0x00000000327c1265 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:613: DB::InterpreterSystemQuery::execute() @ 0x00000000337e14a7 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 09:07:55.897453 [ 43342 ] {38900dd1-b167-476c-9e3d-e8e0ecbc5d29} executeQuery: Code: 704. DB::Exception: The query result was not cached because the query contains a non-deterministic function. Use setting `query_cache_nondeterministic_function_handling = 'save'` or `= 'ignore'` to cache the query result regardless or to omit caching. (QUERY_CACHE_USED_WITH_NONDETERMINISTIC_FUNCTIONS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60894) (comment: 02494_query_cache_nondeterministic_functions.sql) (query 3, line 7) (in query: SELECT count(now()) SETTINGS use_query_cache = true;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1473: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003373a09c 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 6. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 2025.06.13 09:07:55.909226 [ 43342 ] {} TCPHandler: Code: 704. DB::Exception: The query result was not cached because the query contains a non-deterministic function. Use setting `query_cache_nondeterministic_function_handling = 'save'` or `= 'ignore'` to cache the query result regardless or to omit caching. (QUERY_CACHE_USED_WITH_NONDETERMINISTIC_FUNCTIONS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1473: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003373a09c 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 6. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 2025.06.13 09:07:55.976266 [ 43342 ] {c7d8ca62-e28b-405d-bc59-2fc499e73ce4} executeQuery: Code: 704. DB::Exception: The query result was not cached because the query contains a non-deterministic function. Use setting `query_cache_nondeterministic_function_handling = 'save'` or `= 'ignore'` to cache the query result regardless or to omit caching. (QUERY_CACHE_USED_WITH_NONDETERMINISTIC_FUNCTIONS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60894) (comment: 02494_query_cache_nondeterministic_functions.sql) (query 4, line 8) (in query: SELECT count(now()) SETTINGS use_query_cache = true, query_cache_nondeterministic_function_handling = 'throw';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1473: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003373a09c 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 6. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 2025.06.13 09:07:55.983139 [ 43342 ] {} TCPHandler: Code: 704. DB::Exception: The query result was not cached because the query contains a non-deterministic function. Use setting `query_cache_nondeterministic_function_handling = 'save'` or `= 'ignore'` to cache the query result regardless or to omit caching. (QUERY_CACHE_USED_WITH_NONDETERMINISTIC_FUNCTIONS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1473: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003373a09c 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 6. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 2025.06.13 09:09:33.085038 [ 43342 ] {32db5a94-da00-4fd4-b65e-3750d2325c14} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `test_id` in scope SELECT test_id FROM test_table. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35022) (comment: 02337_analyzer_columns_basic.sql) (query 15, line 33) (in query: SELECT test_id FROM test_table;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000303dd3a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032b465 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:09:33.091987 [ 43342 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `test_id` in scope SELECT test_id FROM test_table. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000303dd3a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032b465 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:09:33.127701 [ 43342 ] {fdb1d5f6-1a1e-4595-9d2a-7ec010f83edd} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_unknown_table' in scope SELECT test_id FROM test_unknown_table. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35022) (comment: 02337_analyzer_columns_basic.sql) (query 16, line 34) (in query: SELECT test_id FROM test_unknown_table;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 09:09:33.134764 [ 43342 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_unknown_table' in scope SELECT test_id FROM test_unknown_table. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 09:10:30.475447 [ 43342 ] {d0c9050c-0e50-4104-984d-e995d25ba526} executeQuery: Code: 201. DB::Exception: Quota for user `u02246` for 3155695200s has been exceeded: query_inserts = 3/2. Interval will end at 2069-12-31 01:00:00. Name of quota template: `q02246`. (QUOTA_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33856) (comment: 02246_async_insert_quota.sh) (query 1, line 1) (in query: INSERT INTO async_inserts_02246 VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&, String&&, String&&) @ 0x000000002e3d6547 4. ./build_docker/./src/Access/EnabledQuota.cpp:32: DB::EnabledQuota::Impl::throwQuotaExceed(String const&, String const&, DB::QuotaType, unsigned long, unsigned long, std::chrono::duration>, std::chrono::time_point>>) @ 0x000000002e3d5fc9 5. ./build_docker/./src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::Impl::used(String const&, DB::EnabledQuota::Intervals const&, DB::QuotaType, unsigned long, std::chrono::time_point>>, bool) @ 0x000000002e3d507b 6. ./build_docker/./src/Access/EnabledQuota.cpp:252: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x000000002e3d14c1 7. ./build_docker/./src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x000000002e3d1389 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1279: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003372d8bd 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:10:30.486432 [ 43342 ] {} TCPHandler: Code: 201. DB::Exception: Quota for user `u02246` for 3155695200s has been exceeded: query_inserts = 3/2. Interval will end at 2069-12-31 01:00:00. Name of quota template: `q02246`. (QUOTA_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&, String&&, String&&) @ 0x000000002e3d6547 4. ./build_docker/./src/Access/EnabledQuota.cpp:32: DB::EnabledQuota::Impl::throwQuotaExceed(String const&, String const&, DB::QuotaType, unsigned long, unsigned long, std::chrono::duration>, std::chrono::time_point>>) @ 0x000000002e3d5fc9 5. ./build_docker/./src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::Impl::used(String const&, DB::EnabledQuota::Intervals const&, DB::QuotaType, unsigned long, std::chrono::time_point>>, bool) @ 0x000000002e3d507b 6. ./build_docker/./src/Access/EnabledQuota.cpp:252: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x000000002e3d14c1 7. ./build_docker/./src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x000000002e3d1389 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1279: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003372d8bd 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:10:39.008332 [ 43342 ] {c4d54de3-b3a3-432d-abb0-f90a78b5290a} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a Parquet format file. Error: Code: 50. DB::Exception: Unsupported Parquet type 'null' of an input column 'error_message'. If it happens during schema inference and you want to skip columns with unsupported types, you can enable setting input_format_parquet_skip_columns_with_unsupported_types_in_schema_inference. (UNKNOWN_TYPE) (version 25.3.3.20286.altinityantalya (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/test_02245.parquet). (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51038) (comment: 02245_parquet_skip_unknown_type.sh) (query 1, line 1) (in query: desc file(test_02245.parquet)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001a317bad 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:287: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003afd7729 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003afd97ae 6. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000383fa9db 7. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000383fbede 8. ./build_docker/./src/TableFunctions/TableFunctionFile.cpp:119: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002660b1f3 9. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x00000000338721cc 10. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x000000003386e605 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 09:10:39.019396 [ 43342 ] {} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a Parquet format file. Error: Code: 50. DB::Exception: Unsupported Parquet type 'null' of an input column 'error_message'. If it happens during schema inference and you want to skip columns with unsupported types, you can enable setting input_format_parquet_skip_columns_with_unsupported_types_in_schema_inference. (UNKNOWN_TYPE) (version 25.3.3.20286.altinityantalya (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/test_02245.parquet). (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001a317bad 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:287: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003afd7729 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003afd97ae 6. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000383fa9db 7. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000383fbede 8. ./build_docker/./src/TableFunctions/TableFunctionFile.cpp:119: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002660b1f3 9. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x00000000338721cc 10. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x000000003386e605 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 09:11:12.020570 [ 410 ] {} CgroupsReader: Cannot find 'kernel' in '/sys/fs/cgroup/memory.stat' (skipped 5896 similar messages) 2025.06.13 09:11:34.036843 [ 43342 ] {f0a34605-3e05-4ccb-9174-079dbdf1e806} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `a` in scope SELECT a FROM merge(REGEXP('.'), '^t$'). Maybe you meant: ['b']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43238) (comment: 02024_merge_regexp_assert.sql) (query 3, line 6) (in query: SELECT a FROM merge(REGEXP('.'), '^t$');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000303dd3a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032b465 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:11:34.045659 [ 43342 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `a` in scope SELECT a FROM merge(REGEXP('.'), '^t$'). Maybe you meant: ['b']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000303dd3a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032b465 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:11:34.094361 [ 43342 ] {71f86207-8efd-4d68-9f44-208816998dd9} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `a` in scope SELECT a FROM merge(REGEXP('\0'), '^t$'). Maybe you meant: ['b']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43238) (comment: 02024_merge_regexp_assert.sql) (query 4, line 7) (in query: SELECT a FROM merge(REGEXP('\0'), '^t$');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000303dd3a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032b465 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:11:34.103156 [ 43342 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `a` in scope SELECT a FROM merge(REGEXP('\0'), '^t$'). Maybe you meant: ['b']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000303dd3a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032b465 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:11:34.150960 [ 43342 ] {76732ca3-5650-41f5-b475-caa2d315d5e6} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `a` in scope SELECT a FROM merge(REGEXP('\0a'), '^t$'). Maybe you meant: ['b']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43238) (comment: 02024_merge_regexp_assert.sql) (query 5, line 8) (in query: SELECT a FROM merge(REGEXP('\0a'), '^t$');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000303dd3a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032b465 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:11:34.159241 [ 43342 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `a` in scope SELECT a FROM merge(REGEXP('\0a'), '^t$'). Maybe you meant: ['b']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000303dd3a7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032b465 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:11:34.416915 [ 43342 ] {e140e4d4-cfc3-47eb-9ea1-2fc54104da3a} executeQuery: Code: 636. DB::Exception: There are no tables satisfied provided regexp, you must specify table structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43238) (comment: 02024_merge_regexp_assert.sql) (query 6, line 9) (in query: SELECT a FROM merge(REGEXP('\0a'), '^$');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageMerge.cpp:210: DB::StorageMerge::getColumnsDescriptionFromSourceTables(std::shared_ptr const&) const @ 0x0000000038694fd0 5. ./build_docker/./src/Storages/StorageMerge.cpp:182: DB::StorageMerge::StorageMerge(DB::StorageID const&, DB::ColumnsDescription const&, String const&, String const&, bool, String const&, std::shared_ptr) @ 0x000000003869661f 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, DB::ColumnsDescription, String, String const&, bool const&, String const&, std::shared_ptr&, 0>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&&, String&&, String const&, bool const&, String const&, std::shared_ptr&) @ 0x000000002658bada 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMerge::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002658961d 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d0326ad 9. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316edd5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030336f50 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 09:11:34.424125 [ 43342 ] {} TCPHandler: Code: 636. DB::Exception: There are no tables satisfied provided regexp, you must specify table structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageMerge.cpp:210: DB::StorageMerge::getColumnsDescriptionFromSourceTables(std::shared_ptr const&) const @ 0x0000000038694fd0 5. ./build_docker/./src/Storages/StorageMerge.cpp:182: DB::StorageMerge::StorageMerge(DB::StorageID const&, DB::ColumnsDescription const&, String const&, String const&, bool, String const&, std::shared_ptr) @ 0x000000003869661f 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, DB::ColumnsDescription, String, String const&, bool const&, String const&, std::shared_ptr&, 0>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&&, String&&, String const&, bool const&, String const&, std::shared_ptr&) @ 0x000000002658bada 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMerge::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002658961d 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d0326ad 9. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316edd5f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030336f50 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 09:12:09.019647 [ 43342 ] {} DNSResolver: Cannot resolve host (non.existing.host.name), error 0: Host not found. 2025.06.13 09:12:09.021503 [ 43342 ] {} AddressPatterns: Failed to check if the allowed client hosts contain address 2001:3984:3989::242:ac11:2. DB::NetException: Not found address of host: non.existing.host.name, code = 198 2025.06.13 09:12:37.513538 [ 4765 ] {c63857e8-6810-4d7e-99ec-23bccad064cb} ExternalDictionariesLoader: Could not load external dictionary '9d1e9ba2-61d5-48c6-8009-b039318769a7', next update is scheduled at 2025-06-13 09:12:43: Code: 1. DB::Exception: test_wkiy9zem.ip_trie_dictionary (9d1e9ba2-61d5-48c6-8009-b039318769a7): array or nullable attributes not supported for dictionary of type Trie. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Dictionaries/IPAddressDictionary.cpp:385: DB::IPAddressDictionary::createAttributes()::$_0::operator()(std::vector> const&) const @ 0x0000000027001a52 5. ./build_docker/./src/Dictionaries/IPAddressDictionary.cpp:401: DB::IPAddressDictionary::IPAddressDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::IPAddressDictionary::Configuration) @ 0x0000000026feeaa6 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x00000000270ae022 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 8. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 10. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 32. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 33. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 34. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 35. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 36. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 37. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 38. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 39. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 40. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 41. ? @ 0x00007f5206343ac3 42. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:12:37.531439 [ 43342 ] {c63857e8-6810-4d7e-99ec-23bccad064cb} executeQuery: Code: 1. DB::Exception: test_wkiy9zem.ip_trie_dictionary (9d1e9ba2-61d5-48c6-8009-b039318769a7): array or nullable attributes not supported for dictionary of type Trie: In scope SELECT dictGet('ip_trie_dictionary', 'value', tuple(IPv4StringToNum('127.0.0.0'))). (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35982) (comment: 01904_dictionary_default_nullable_type.sql) (query 50, line 112) (in query: SELECT dictGet('ip_trie_dictionary', 'value', tuple(IPv4StringToNum('127.0.0.0')));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Dictionaries/IPAddressDictionary.cpp:385: DB::IPAddressDictionary::createAttributes()::$_0::operator()(std::vector> const&) const @ 0x0000000027001a52 5. ./build_docker/./src/Dictionaries/IPAddressDictionary.cpp:401: DB::IPAddressDictionary::IPAddressDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::IPAddressDictionary::Configuration) @ 0x0000000026feeaa6 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x00000000270ae022 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 8. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 10. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:12:37.543364 [ 43342 ] {} TCPHandler: Code: 1. DB::Exception: test_wkiy9zem.ip_trie_dictionary (9d1e9ba2-61d5-48c6-8009-b039318769a7): array or nullable attributes not supported for dictionary of type Trie: In scope SELECT dictGet('ip_trie_dictionary', 'value', tuple(IPv4StringToNum('127.0.0.0'))). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Dictionaries/IPAddressDictionary.cpp:385: DB::IPAddressDictionary::createAttributes()::$_0::operator()(std::vector> const&) const @ 0x0000000027001a52 5. ./build_docker/./src/Dictionaries/IPAddressDictionary.cpp:401: DB::IPAddressDictionary::IPAddressDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::IPAddressDictionary::Configuration) @ 0x0000000026feeaa6 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x00000000270ae022 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 8. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 10. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 32. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 33. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 34. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 35. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 36. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 37. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 38. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 39. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 40. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 41. ? @ 0x00007f5206343ac3 42. ? @ 0x00007f52063d5850 2025.06.13 09:13:20.161778 [ 43342 ] {b0a3789b-f41b-4f01-ac33-83e6ec6091e7} executeQuery: Code: 591. DB::Exception: Failed to fetch table structure for '); select 1 --. (SQLITE_ENGINE_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44972) (comment: 01889_sqlite_read_write.sh) (query 1, line 1) (in query: SELECT * FROM sqlite('/var/lib/clickhouse/user_files/test_01889_sqllite_test_irc8cl7g_db1', '\'); select 1 --') ORDER BY col2 -- { serverError SQLITE_ENGINE_ERROR }), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/StorageSQLite.cpp:87: DB::StorageSQLite::getTableStructureFromData(std::shared_ptr const&, String const&) @ 0x0000000038c31cd9 5. ./build_docker/./src/Storages/StorageSQLite.cpp:68: DB::StorageSQLite::StorageSQLite(DB::StorageID const&, std::shared_ptr, String const&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr) @ 0x0000000038c30c13 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageSQLite* std::construct_at[abi:ne190107] const&, String const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, char const (&) [1], std::shared_ptr&, DB::StorageSQLite*>(DB::StorageSQLite*, DB::StorageID&&, std::shared_ptr const&, String const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, char const (&) [1], std::shared_ptr&) @ 0x00000000266b5272 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, std::shared_ptr const&, String const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, char const (&) [1], std::shared_ptr&, 0>(std::allocator const&, DB::StorageID&&, std::shared_ptr const&, String const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, char const (&) [1], std::shared_ptr&) @ 0x00000000266b4bd8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionSQLite::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000266b4548 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d0326ad 10. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316edd5f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030336f50 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 09:13:20.169426 [ 43342 ] {} TCPHandler: Code: 591. DB::Exception: Failed to fetch table structure for '); select 1 --. (SQLITE_ENGINE_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/StorageSQLite.cpp:87: DB::StorageSQLite::getTableStructureFromData(std::shared_ptr const&, String const&) @ 0x0000000038c31cd9 5. ./build_docker/./src/Storages/StorageSQLite.cpp:68: DB::StorageSQLite::StorageSQLite(DB::StorageID const&, std::shared_ptr, String const&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr) @ 0x0000000038c30c13 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageSQLite* std::construct_at[abi:ne190107] const&, String const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, char const (&) [1], std::shared_ptr&, DB::StorageSQLite*>(DB::StorageSQLite*, DB::StorageID&&, std::shared_ptr const&, String const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, char const (&) [1], std::shared_ptr&) @ 0x00000000266b5272 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, std::shared_ptr const&, String const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, char const (&) [1], std::shared_ptr&, 0>(std::allocator const&, DB::StorageID&&, std::shared_ptr const&, String const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, char const (&) [1], std::shared_ptr&) @ 0x00000000266b4bd8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionSQLite::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000266b4548 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d0326ad 10. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316edd5f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030336f50 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8f3f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 31. ? @ 0x00007f5206343ac3 2025.06.13 09:14:14.963833 [ 43325 ] {81f0279a-33ec-4c28-8dd0-4ddf4cd4a21f} executeQuery: Code: 36. DB::Exception: Dictionary attributes names must be unique. Attribute name value1 is not unique. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48592) (comment: 01759_dictionary_unique_attribute_names.sql) (query 5, line 16) (in query: CREATE DICTIONARY 01759_db.test_dictionary(key UInt64, value1 UInt64, value1 UInt64) PRIMARY KEY key SOURCE(CLICKHOUSE(HOST 'localhost' PORT tcpPort() USER 'default' TABLE 'dictionary_source_table' DB '01759_db')) LAYOUT(COMPLEX_KEY_DIRECT());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Dictionaries/DictionaryStructure.cpp:302: DB::DictionaryStructure::getAttributes(Poco::Util::AbstractConfiguration const&, String const&, bool) @ 0x000000002bfdd35c 5. ./build_docker/./src/Dictionaries/DictionaryStructure.cpp:97: DB::DictionaryStructure::DictionaryStructure(Poco::Util::AbstractConfiguration const&, String const&) @ 0x000000002bfd38fd 6. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:214: DB::ExternalDictionariesLoader::getDictionaryStructure(Poco::Util::AbstractConfiguration const&, String const&) @ 0x00000000327c4dbc 7. ./build_docker/./src/Storages/StorageDictionary.cpp:143: DB::StorageDictionary::StorageDictionary(DB::StorageID const&, Poco::AutoPtr, std::shared_ptr) @ 0x000000003833c4ca 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::shared_ptr&, std::allocator, 0>(std::allocator, DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&) @ 0x0000000038348bca 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&, 0>(std::allocator const&, DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&) @ 0x00000000383488c3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000038345e52 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 09:14:14.971815 [ 43325 ] {} TCPHandler: Code: 36. DB::Exception: Dictionary attributes names must be unique. Attribute name value1 is not unique. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Dictionaries/DictionaryStructure.cpp:302: DB::DictionaryStructure::getAttributes(Poco::Util::AbstractConfiguration const&, String const&, bool) @ 0x000000002bfdd35c 5. ./build_docker/./src/Dictionaries/DictionaryStructure.cpp:97: DB::DictionaryStructure::DictionaryStructure(Poco::Util::AbstractConfiguration const&, String const&) @ 0x000000002bfd38fd 6. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:214: DB::ExternalDictionariesLoader::getDictionaryStructure(Poco::Util::AbstractConfiguration const&, String const&) @ 0x00000000327c4dbc 7. ./build_docker/./src/Storages/StorageDictionary.cpp:143: DB::StorageDictionary::StorageDictionary(DB::StorageID const&, Poco::AutoPtr, std::shared_ptr) @ 0x000000003833c4ca 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::shared_ptr&, std::allocator, 0>(std::allocator, DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&) @ 0x0000000038348bca 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&, 0>(std::allocator const&, DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&) @ 0x00000000383488c3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000038345e52 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 24. ? @ 0x00007f5206343ac3 25. ? @ 0x00007f52063d5850 2025.06.13 09:14:45.334971 [ 43325 ] {2fd238ff-e23f-4160-aa88-90b576cc02f6} executeQuery: Code: 107. DB::ErrnoException: Cannot open file /var/lib/clickhouse/user_files/nonexist.txt: , errno: 2, strerror: No such file or directory: In scope SELECT file('nonexist.txt'), file('b.txt'). (FILE_DOESNT_EXIST) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44076) (comment: 01658_read_file_to_stringcolumn.sh) (query 1, line 1) (in query: select file('nonexist.txt'), file('b.txt')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String&) @ 0x000000001f865f6f 4. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String&) @ 0x000000001f8655e8 5. ./build_docker/./src/IO/ReadBufferFromFile.cpp:48: DB::ReadBufferFromFile::ReadBufferFromFile(String const&, unsigned long, int, char*, unsigned long, std::optional, std::shared_ptr) @ 0x000000001f87bf2a 6. DB::FunctionFile::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008bbf05a 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 2025.06.13 09:14:45.347223 [ 43325 ] {} TCPHandler: Code: 107. DB::ErrnoException: Cannot open file /var/lib/clickhouse/user_files/nonexist.txt: , errno: 2, strerror: No such file or directory: In scope SELECT file('nonexist.txt'), file('b.txt'). (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String&) @ 0x000000001f865f6f 4. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String&) @ 0x000000001f8655e8 5. ./build_docker/./src/IO/ReadBufferFromFile.cpp:48: DB::ReadBufferFromFile::ReadBufferFromFile(String const&, unsigned long, int, char*, unsigned long, std::optional, std::shared_ptr) @ 0x000000001f87bf2a 6. DB::FunctionFile::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008bbf05a 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 2025.06.13 09:14:46.450172 [ 43325 ] {3c2b59ab-6050-46f2-91fe-990b666d0e64} executeQuery: Code: 74. DB::ErrnoException: Cannot read from file /var/lib/clickhouse/user_files/dir: , errno: 21, strerror: Is a directory: In scope SELECT file('dir'), file('b.txt'). (CANNOT_READ_FROM_FILE_DESCRIPTOR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44082) (comment: 01658_read_file_to_stringcolumn.sh) (query 1, line 1) (in query: select file('dir'), file('b.txt')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String&&) @ 0x000000001f854c8f 4. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String&&) @ 0x000000001f853888 5. ./build_docker/./src/IO/ReadBufferFromFileDescriptor.cpp:83: DB::ReadBufferFromFileDescriptor::readImpl(char*, unsigned long, unsigned long, unsigned long) const @ 0x000000001f88073a 6. ./build_docker/./src/IO/ReadBufferFromFileDescriptor.cpp:124: DB::ReadBufferFromFileDescriptor::nextImpl() @ 0x000000001f8809e9 7. DB::ReadBuffer::next() @ 0x0000000008e83ccf 8. ./src/IO/ReadBuffer.h:96: DB::(anonymous namespace)::copyDataImpl(DB::ReadBuffer&, DB::WriteBuffer&, bool, unsigned long, std::atomic const*, std::shared_ptr) @ 0x000000001f916f26 9. ./build_docker/./src/IO/copyData.cpp:67: DB::copyData(DB::ReadBuffer&, DB::WriteBuffer&) @ 0x000000001f916bc5 10. DB::FunctionFile::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008bbf389 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 2025.06.13 09:14:46.462577 [ 43325 ] {} TCPHandler: Code: 74. DB::ErrnoException: Cannot read from file /var/lib/clickhouse/user_files/dir: , errno: 21, strerror: Is a directory: In scope SELECT file('dir'), file('b.txt'). (CANNOT_READ_FROM_FILE_DESCRIPTOR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String&&) @ 0x000000001f854c8f 4. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String&&) @ 0x000000001f853888 5. ./build_docker/./src/IO/ReadBufferFromFileDescriptor.cpp:83: DB::ReadBufferFromFileDescriptor::readImpl(char*, unsigned long, unsigned long, unsigned long) const @ 0x000000001f88073a 6. ./build_docker/./src/IO/ReadBufferFromFileDescriptor.cpp:124: DB::ReadBufferFromFileDescriptor::nextImpl() @ 0x000000001f8809e9 7. DB::ReadBuffer::next() @ 0x0000000008e83ccf 8. ./src/IO/ReadBuffer.h:96: DB::(anonymous namespace)::copyDataImpl(DB::ReadBuffer&, DB::WriteBuffer&, bool, unsigned long, std::atomic const*, std::shared_ptr) @ 0x000000001f916f26 9. ./build_docker/./src/IO/copyData.cpp:67: DB::copyData(DB::ReadBuffer&, DB::WriteBuffer&) @ 0x000000001f916bc5 10. DB::FunctionFile::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008bbf389 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 2025.06.13 09:14:47.641740 [ 43325 ] {b4dd2f2f-a7aa-42a5-97f2-a3840c879f25} executeQuery: Code: 291. DB::Exception: File is not inside /var/lib/clickhouse/user_files: In scope SELECT file('/tmp/c.txt'), file('b.txt'). (DATABASE_ACCESS_DENIED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44088) (comment: 01658_read_file_to_stringcolumn.sh) (query 1, line 1) (in query: select file('/tmp/c.txt'), file('b.txt')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::FunctionFile::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008bbf804 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 09:14:47.654324 [ 43325 ] {} TCPHandler: Code: 291. DB::Exception: File is not inside /var/lib/clickhouse/user_files: In scope SELECT file('/tmp/c.txt'), file('b.txt'). (DATABASE_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::FunctionFile::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008bbf804 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 09:14:48.545676 [ 43325 ] {33bbcccc-cffb-4335-b8b3-78f46fab1335} executeQuery: Code: 291. DB::Exception: File is not inside /var/lib/clickhouse/user_files: In scope SELECT file('../../../../../../../../../../../../../../../../../../../tmp/c.txt'), file('b.txt'). (DATABASE_ACCESS_DENIED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44100) (comment: 01658_read_file_to_stringcolumn.sh) (query 1, line 1) (in query: select file('../../../../../../../../../../../../../../../../../../../tmp/c.txt'), file('b.txt')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::FunctionFile::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008bbf804 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 09:14:48.559309 [ 43325 ] {} TCPHandler: Code: 291. DB::Exception: File is not inside /var/lib/clickhouse/user_files: In scope SELECT file('../../../../../../../../../../../../../../../../../../../tmp/c.txt'), file('b.txt'). (DATABASE_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::FunctionFile::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008bbf804 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 09:14:49.421309 [ 43325 ] {1bfb2123-570c-45a7-aa34-5dab8ab65efc} executeQuery: Code: 291. DB::Exception: File is not inside /var/lib/clickhouse/user_files: In scope SELECT file('../../../../a.txt'), file('b.txt'). (DATABASE_ACCESS_DENIED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44104) (comment: 01658_read_file_to_stringcolumn.sh) (query 1, line 1) (in query: select file('../../../../a.txt'), file('b.txt')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::FunctionFile::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008bbf804 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 09:14:49.434875 [ 43325 ] {} TCPHandler: Code: 291. DB::Exception: File is not inside /var/lib/clickhouse/user_files: In scope SELECT file('../../../../a.txt'), file('b.txt'). (DATABASE_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. DB::FunctionFile::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008bbf804 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303869cf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 09:14:58.822715 [ 45838 ] {7ce7d168-107b-4cce-aeea-805eecc02c34} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 4.01 MiB (attempt to allocate chunk of 1.00 MiB bytes), maximum: 3.81 MiB.: while executing 'FUNCTION repeat('aa'_String :: 1, __table1.number :: 2) -> repeat('aa'_String, __table1.number) String : 0'. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53548) (comment: 01656_test_query_log_factories_info.sql) (query 4, line 20) (in query: SELECT repeat('aa', number) FROM numbers(10e3) SETTINGS max_memory_usage=4e6, max_block_size=100 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f53cbed 8. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008badd72 9. auto DB::(anonymous namespace)::FunctionRepeat::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda1'(auto const&)::operator()>(auto const&) const @ 0x000000001a21a41a 10. DB::(anonymous namespace)::FunctionRepeat::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a205907 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 17. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 09:14:58.836804 [ 45838 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 4.01 MiB (attempt to allocate chunk of 1.00 MiB bytes), maximum: 3.81 MiB.: while executing 'FUNCTION repeat('aa'_String :: 1, __table1.number :: 2) -> repeat('aa'_String, __table1.number) String : 0'. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f53cbed 8. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008badd72 9. auto DB::(anonymous namespace)::FunctionRepeat::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda1'(auto const&)::operator()>(auto const&) const @ 0x000000001a21a41a 10. DB::(anonymous namespace)::FunctionRepeat::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a205907 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 17. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:15:11.486633 [ 45838 ] {0ba328b5-3a06-4dc5-8f09-9375c239dfc5} executeQuery: Code: 390. DB::Exception: Table `not_exist_view` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:32840) (comment: 01602_show_create_view.sql) (query 12, line 25) (in query: SHOW CREATE VIEW test_1602.not_exist_view;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:549: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x000000002f8762da 5. ./src/Databases/IDatabase.h:350: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000033865480 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:34: DB::InterpreterShowCreateQuery::execute() @ 0x0000000033864644 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:15:11.493433 [ 45838 ] {} TCPHandler: Code: 390. DB::Exception: Table `not_exist_view` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:549: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x000000002f8762da 5. ./src/Databases/IDatabase.h:350: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000033865480 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:34: DB::InterpreterShowCreateQuery::execute() @ 0x0000000033864644 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:15:11.651338 [ 45838 ] {f3f8ffd9-e20f-475e-af5b-723ef4050f3d} executeQuery: Code: 36. DB::Exception: `test_1602`.`tbl` is not a VIEW. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:32840) (comment: 01602_show_create_view.sql) (query 13, line 27) (in query: SHOW CREATE VIEW test_1602.tbl;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:72: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000033868a34 5. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:34: DB::InterpreterShowCreateQuery::execute() @ 0x0000000033864644 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:15:11.659327 [ 45838 ] {} TCPHandler: Code: 36. DB::Exception: `test_1602`.`tbl` is not a VIEW. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:72: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000033868a34 5. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:34: DB::InterpreterShowCreateQuery::execute() @ 0x0000000033864644 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:15:11.812146 [ 45838 ] {c1ca3459-9369-4fe9-8896-5d3c7c409282} executeQuery: Code: 60. DB::Exception: Cannot resolve database name for table VIEW. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:32840) (comment: 01602_show_create_view.sql) (query 14, line 29) (in query: SHOW CREATE TEMPORARY VIEW;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Context::resolveStorageIDImpl(DB::StorageID, DB::Context::StorageNamespace, std::optional*) const @ 0x0000000031750902 4. ./build_docker/./src/Interpreters/Context.cpp:5675: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000003174efde 5. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:57: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000033864c9b 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:34: DB::InterpreterShowCreateQuery::execute() @ 0x0000000033864644 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:15:11.820444 [ 45838 ] {} TCPHandler: Code: 60. DB::Exception: Cannot resolve database name for table VIEW. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Context::resolveStorageIDImpl(DB::StorageID, DB::Context::StorageNamespace, std::optional*) const @ 0x0000000031750902 4. ./build_docker/./src/Interpreters/Context.cpp:5675: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000003174efde 5. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:57: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000033864c9b 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:34: DB::InterpreterShowCreateQuery::execute() @ 0x0000000033864644 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:15:14.077529 [ 45838 ] {aa5e489b-2a71-46fb-a8cf-50ba8c5c67cd} executeQuery: Code: 57. DB::Exception: Table `test1601_detach_permanently_atomic`.`test_name_reuse` already exists (detached permanently). (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59946) (comment: 01601_detach_permanently.sql) (query 9, line 17) (in query: create table test1601_detach_permanently_atomic.test_name_reuse (number UInt64) engine=MergeTree order by tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:412: DB::DatabaseOnDisk::checkMetadataFilenameAvailabilityUnlocked(String const&) const @ 0x000000002f86ff89 5. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:391: DB::DatabaseOnDisk::checkMetadataFilenameAvailability(String const&) const @ 0x000000002f86f449 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1835: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291408a 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:15:14.084883 [ 45838 ] {} TCPHandler: Code: 57. DB::Exception: Table `test1601_detach_permanently_atomic`.`test_name_reuse` already exists (detached permanently). (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:412: DB::DatabaseOnDisk::checkMetadataFilenameAvailabilityUnlocked(String const&) const @ 0x000000002f86ff89 5. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:391: DB::DatabaseOnDisk::checkMetadataFilenameAvailability(String const&) const @ 0x000000002f86f449 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1835: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291408a 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:15:14.359105 [ 45838 ] {4c4d6032-f340-4daa-bdb1-e2717dc30595} executeQuery: Code: 60. DB::Exception: Table test1601_detach_permanently_atomic.test_name_reuse does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59946) (comment: 01601_detach_permanently.sql) (query 11, line 20) (in query: DETACH table test1601_detach_permanently_atomic.test_name_reuse PERMANENTLY;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8528 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0eed4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003296ac6b 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032968e1f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965c79 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 09:15:14.365905 [ 45838 ] {} TCPHandler: Code: 60. DB::Exception: Table test1601_detach_permanently_atomic.test_name_reuse does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8528 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0eed4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003296ac6b 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032968e1f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965c79 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 09:15:14.392915 [ 45838 ] {10b000b6-4bbd-4a5c-ad82-20be49cdeb84} executeQuery: Code: 60. DB::Exception: Table test1601_detach_permanently_atomic.test_name_reuse does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59946) (comment: 01601_detach_permanently.sql) (query 12, line 21) (in query: DETACH table test1601_detach_permanently_atomic.test_name_reuse;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8528 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0eed4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003296ac6b 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032968e1f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965c79 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 09:15:14.399784 [ 45838 ] {} TCPHandler: Code: 60. DB::Exception: Table test1601_detach_permanently_atomic.test_name_reuse does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8528 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0eed4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003296ac6b 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032968e1f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965c79 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 09:15:14.509238 [ 45838 ] {1fc60df3-3e7f-49e1-bf65-6a7e3cf1b3f0} executeQuery: Code: 60. DB::Exception: Table test1601_detach_permanently_atomic.test_name_reuse does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59946) (comment: 01601_detach_permanently.sql) (query 14, line 24) (in query: drop table test1601_detach_permanently_atomic.test_name_reuse;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8528 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0eed4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003296ac6b 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032968e1f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965c79 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 09:15:14.515464 [ 45838 ] {} TCPHandler: Code: 60. DB::Exception: Table test1601_detach_permanently_atomic.test_name_reuse does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8528 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0eed4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003296ac6b 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032968e1f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965c79 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 09:15:14.844951 [ 45838 ] {9232d111-0e16-4b57-a025-94c166e50d82} executeQuery: Code: 57. DB::Exception: Table `test1601_detach_permanently_atomic`.`test_name_reuse` already exists (detached permanently). (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59946) (comment: 01601_detach_permanently.sql) (query 17, line 29) (in query: RENAME TABLE test1601_detach_permanently_atomic.test_name_rename_attempt TO test1601_detach_permanently_atomic.test_name_reuse;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:412: DB::DatabaseOnDisk::checkMetadataFilenameAvailabilityUnlocked(String const&) const @ 0x000000002f86ff89 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:295: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x000000002f808b1c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a037d4 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:15:14.852041 [ 45838 ] {} TCPHandler: Code: 57. DB::Exception: Table `test1601_detach_permanently_atomic`.`test_name_reuse` already exists (detached permanently). (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:412: DB::DatabaseOnDisk::checkMetadataFilenameAvailabilityUnlocked(String const&) const @ 0x000000002f86ff89 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:295: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x000000002f808b1c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a037d4 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:15:15.033212 [ 45838 ] {0d052a24-89ae-481d-babb-9c745d3747a5} executeQuery: Code: 60. DB::Exception: Table `test1601_detach_permanently_atomic`.`test_name_reuse` doesn't exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59946) (comment: 01601_detach_permanently.sql) (query 18, line 30) (in query: EXCHANGE TABLES test1601_detach_permanently_atomic.test_name_rename_attempt AND test1601_detach_permanently_atomic.test_name_reuse;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x000000002f9dc4a8 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:310: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x000000002f80912d 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a037d4 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:15:15.040483 [ 45838 ] {} TCPHandler: Code: 60. DB::Exception: Table `test1601_detach_permanently_atomic`.`test_name_reuse` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x000000002f9dc4a8 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:310: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x000000002f80912d 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a037d4 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:15:15.287665 [ 45838 ] {ffcaa01c-4c83-424e-b638-0698c565cb12} InterpreterCreateQuery: ATTACH TABLE query with full table definition is not recommended: use either ATTACH TABLE test_name_reuse; to attach existing table or CREATE TABLE test_name_reuse
; to create new table or ATTACH TABLE test_name_reuse FROM '/path/to/data/'
; to create new table and attach data. 2025.06.13 09:15:15.499202 [ 45838 ] {ffcaa01c-4c83-424e-b638-0698c565cb12} executeQuery: Code: 57. DB::Exception: Table `test1601_detach_permanently_atomic`.`test_name_reuse` already exist (detached or detached permanently). To attach it back you need to use short ATTACH syntax (ATTACH TABLE `test1601_detach_permanently_atomic`.`test_name_reuse`;). (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59946) (comment: 01601_detach_permanently.sql) (query 22, line 36) (in query: ATTACH TABLE test1601_detach_permanently_atomic.test_name_reuse UUID '00000000-0000-0000-0000-000000000001' (`number` UInt64 ) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 8192 ;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:253: DB::DatabaseOnDisk::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002f86752e 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2001: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291d91c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:15:15.507132 [ 45838 ] {} TCPHandler: Code: 57. DB::Exception: Table `test1601_detach_permanently_atomic`.`test_name_reuse` already exist (detached or detached permanently). To attach it back you need to use short ATTACH syntax (ATTACH TABLE `test1601_detach_permanently_atomic`.`test_name_reuse`;). (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:253: DB::DatabaseOnDisk::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002f86752e 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2001: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291d91c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:15:15.993164 [ 45838 ] {f59c6f56-e9d8-455a-8805-6ee8948d0fd5} executeQuery: Code: 60. DB::Exception: Table test1601_detach_permanently_atomic.test_name_reuse does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59946) (comment: 01601_detach_permanently.sql) (query 28, line 46) (in query: DETACH table test1601_detach_permanently_atomic.test_name_reuse PERMANENTLY;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8528 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0eed4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003296ac6b 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032968e1f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965c79 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 09:15:15.999702 [ 45838 ] {} TCPHandler: Code: 60. DB::Exception: Table test1601_detach_permanently_atomic.test_name_reuse does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8528 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0eed4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003296ac6b 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032968e1f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965c79 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 09:15:16.925106 [ 45838 ] {1f146203-0280-4bc5-887d-b7c826d4c4c4} executeQuery: Code: 60. DB::Exception: Table test1601_detach_permanently_atomic.test_name_reuse does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59946) (comment: 01601_detach_permanently.sql) (query 39, line 62) (in query: DETACH table test1601_detach_permanently_atomic.test_name_reuse PERMANENTLY;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8528 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0eed4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003296ac6b 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032968e1f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965c79 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 09:15:16.931674 [ 45838 ] {} TCPHandler: Code: 60. DB::Exception: Table test1601_detach_permanently_atomic.test_name_reuse does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8528 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0eed4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003296ac6b 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032968e1f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965c79 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 09:15:18.128916 [ 45838 ] {16f44383-f463-4975-ae81-fbd7c41b7cf4} executeQuery: Code: 57. DB::Exception: Table `test1601_detach_permanently_ordinary`.`test_name_reuse` already exists (detached permanently). (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59946) (comment: 01601_detach_permanently.sql) (query 55, line 88) (in query: create table test1601_detach_permanently_ordinary.test_name_reuse (number UInt64) engine=MergeTree order by tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:412: DB::DatabaseOnDisk::checkMetadataFilenameAvailabilityUnlocked(String const&) const @ 0x000000002f86ff89 5. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:391: DB::DatabaseOnDisk::checkMetadataFilenameAvailability(String const&) const @ 0x000000002f86f449 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1835: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291408a 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:15:18.136019 [ 45838 ] {} TCPHandler: Code: 57. DB::Exception: Table `test1601_detach_permanently_ordinary`.`test_name_reuse` already exists (detached permanently). (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:412: DB::DatabaseOnDisk::checkMetadataFilenameAvailabilityUnlocked(String const&) const @ 0x000000002f86ff89 5. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:391: DB::DatabaseOnDisk::checkMetadataFilenameAvailability(String const&) const @ 0x000000002f86f449 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1835: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291408a 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:15:18.240215 [ 45838 ] {a609a517-d10e-449a-b243-accc1c1bee3c} executeQuery: Code: 60. DB::Exception: Table test1601_detach_permanently_ordinary.test_name_reuse does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59946) (comment: 01601_detach_permanently.sql) (query 57, line 91) (in query: DETACH table test1601_detach_permanently_ordinary.test_name_reuse PERMANENTLY;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8528 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0eed4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003296ac6b 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032968e1f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965c79 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 09:15:18.246618 [ 45838 ] {} TCPHandler: Code: 60. DB::Exception: Table test1601_detach_permanently_ordinary.test_name_reuse does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8528 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0eed4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003296ac6b 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032968e1f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965c79 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 09:15:18.271339 [ 45838 ] {f5289635-e27b-4335-a99a-f2c61c60a936} executeQuery: Code: 60. DB::Exception: Table test1601_detach_permanently_ordinary.test_name_reuse does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59946) (comment: 01601_detach_permanently.sql) (query 58, line 92) (in query: DETACH table test1601_detach_permanently_ordinary.test_name_reuse;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8528 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0eed4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003296ac6b 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032968e1f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965c79 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 09:15:18.277696 [ 45838 ] {} TCPHandler: Code: 60. DB::Exception: Table test1601_detach_permanently_ordinary.test_name_reuse does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8528 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0eed4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003296ac6b 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032968e1f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965c79 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 09:15:18.383070 [ 45838 ] {9a15b8ec-0c34-482f-83eb-b76a9fa6f3f8} executeQuery: Code: 60. DB::Exception: Table test1601_detach_permanently_ordinary.test_name_reuse does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59946) (comment: 01601_detach_permanently.sql) (query 60, line 95) (in query: drop table test1601_detach_permanently_ordinary.test_name_reuse;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8528 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0eed4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003296ac6b 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032968e1f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965c79 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 09:15:18.389409 [ 45838 ] {} TCPHandler: Code: 60. DB::Exception: Table test1601_detach_permanently_ordinary.test_name_reuse does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8528 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0eed4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003296ac6b 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032968e1f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965c79 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 09:15:18.731270 [ 45838 ] {68d99f95-b956-4739-adec-7d504e732e74} executeQuery: Code: 57. DB::Exception: Table `test1601_detach_permanently_ordinary`.`test_name_reuse` already exists (detached permanently). (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59946) (comment: 01601_detach_permanently.sql) (query 63, line 100) (in query: RENAME TABLE test1601_detach_permanently_ordinary.test_name_rename_attempt TO test1601_detach_permanently_ordinary.test_name_reuse;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:412: DB::DatabaseOnDisk::checkMetadataFilenameAvailabilityUnlocked(String const&) const @ 0x000000002f86ff89 5. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:391: DB::DatabaseOnDisk::checkMetadataFilenameAvailability(String const&) const @ 0x000000002f86f449 6. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:482: DB::DatabaseOnDisk::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x000000002f87259b 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a037d4 8. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:15:18.738426 [ 45838 ] {} TCPHandler: Code: 57. DB::Exception: Table `test1601_detach_permanently_ordinary`.`test_name_reuse` already exists (detached permanently). (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:412: DB::DatabaseOnDisk::checkMetadataFilenameAvailabilityUnlocked(String const&) const @ 0x000000002f86ff89 5. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:391: DB::DatabaseOnDisk::checkMetadataFilenameAvailability(String const&) const @ 0x000000002f86f449 6. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:482: DB::DatabaseOnDisk::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x000000002f87259b 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a037d4 8. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:15:18.988211 [ 45838 ] {38c139d1-2372-4223-9df3-a5fe26d20830} InterpreterCreateQuery: ATTACH TABLE query with full table definition is not recommended: use either ATTACH TABLE test_name_reuse; to attach existing table or CREATE TABLE test_name_reuse
; to create new table or ATTACH TABLE test_name_reuse FROM '/path/to/data/'
; to create new table and attach data. 2025.06.13 09:15:19.480580 [ 45838 ] {713d7096-7e6f-4791-9f8d-c6fe114b7767} executeQuery: Code: 60. DB::Exception: Table test1601_detach_permanently_ordinary.test_name_reuse does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59946) (comment: 01601_detach_permanently.sql) (query 73, line 115) (in query: DETACH table test1601_detach_permanently_ordinary.test_name_reuse PERMANENTLY;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8528 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0eed4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003296ac6b 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032968e1f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965c79 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 09:15:19.486916 [ 45838 ] {} TCPHandler: Code: 60. DB::Exception: Table test1601_detach_permanently_ordinary.test_name_reuse does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8528 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0eed4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003296ac6b 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032968e1f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965c79 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 09:15:20.192636 [ 45838 ] {eba9d443-1ad5-4e55-87c1-1c887ce4d84f} executeQuery: Code: 60. DB::Exception: Table test1601_detach_permanently_ordinary.test_name_reuse does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59946) (comment: 01601_detach_permanently.sql) (query 83, line 129) (in query: DETACH table test1601_detach_permanently_ordinary.test_name_reuse PERMANENTLY;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8528 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0eed4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003296ac6b 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032968e1f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965c79 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 09:15:20.199074 [ 45838 ] {} TCPHandler: Code: 60. DB::Exception: Table test1601_detach_permanently_ordinary.test_name_reuse does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8528 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0eed4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003296ac6b 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032968e1f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965c79 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 09:15:20.799905 [ 45838 ] {588f1ffd-0aea-4001-9b1a-d8ba28a0376a} executeQuery: Code: 219. DB::Exception: Cannot drop: Cannot remove directory /var/lib/clickhouse/data/test1601_detach_permanently_ordinary/: , errno: 39, strerror: Directory not empty. Probably database contain some detached tables or metadata leftovers from Ordinary engine. If you want to remove all data anyway, try to attach database back and drop it again with enabled force_remove_data_recursively_on_drop setting. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59946) (comment: 01601_detach_permanently.sql) (query 89, line 138) (in query: DROP DATABASE test1601_detach_permanently_ordinary;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x0000000012877c0a 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:611: DB::DatabaseOnDisk::drop(std::shared_ptr) @ 0x000000002f87a9d4 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:627: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031a02ffb 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032977eb2 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032969430 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965ed2 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:15:20.807328 [ 45838 ] {} TCPHandler: Code: 219. DB::Exception: Cannot drop: Cannot remove directory /var/lib/clickhouse/data/test1601_detach_permanently_ordinary/: , errno: 39, strerror: Directory not empty. Probably database contain some detached tables or metadata leftovers from Ordinary engine. If you want to remove all data anyway, try to attach database back and drop it again with enabled force_remove_data_recursively_on_drop setting. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x0000000012877c0a 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:611: DB::DatabaseOnDisk::drop(std::shared_ptr) @ 0x000000002f87a9d4 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:627: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031a02ffb 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032977eb2 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032969430 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965ed2 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:15:21.828492 [ 45838 ] {a183639d-d0a6-4d48-998b-1c8f855d4114} executeQuery: Code: 57. DB::Exception: Table `test1601_detach_permanently_lazy`.`test_name_reuse` already exists (detached permanently). (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59946) (comment: 01601_detach_permanently.sql) (query 103, line 162) (in query: create table test1601_detach_permanently_lazy.test_name_reuse (number UInt64) engine=Log;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:412: DB::DatabaseOnDisk::checkMetadataFilenameAvailabilityUnlocked(String const&) const @ 0x000000002f86ff89 5. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:391: DB::DatabaseOnDisk::checkMetadataFilenameAvailability(String const&) const @ 0x000000002f86f449 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1835: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291408a 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:15:21.839879 [ 45838 ] {} TCPHandler: Code: 57. DB::Exception: Table `test1601_detach_permanently_lazy`.`test_name_reuse` already exists (detached permanently). (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:412: DB::DatabaseOnDisk::checkMetadataFilenameAvailabilityUnlocked(String const&) const @ 0x000000002f86ff89 5. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:391: DB::DatabaseOnDisk::checkMetadataFilenameAvailability(String const&) const @ 0x000000002f86f449 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1835: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291408a 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:15:21.960674 [ 45838 ] {47e4b89c-af79-422a-b770-373281e39d2c} executeQuery: Code: 60. DB::Exception: Table test1601_detach_permanently_lazy.test_name_reuse does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59946) (comment: 01601_detach_permanently.sql) (query 105, line 165) (in query: DETACH table test1601_detach_permanently_lazy.test_name_reuse PERMANENTLY;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8528 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0eed4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003296ac6b 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032968e1f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965c79 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 09:15:21.966924 [ 45838 ] {} TCPHandler: Code: 60. DB::Exception: Table test1601_detach_permanently_lazy.test_name_reuse does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8528 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0eed4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003296ac6b 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032968e1f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965c79 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 09:15:21.991679 [ 45838 ] {738c6ba9-b6ad-4570-8e4e-52b94b92c2f7} executeQuery: Code: 60. DB::Exception: Table test1601_detach_permanently_lazy.test_name_reuse does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59946) (comment: 01601_detach_permanently.sql) (query 106, line 166) (in query: DETACH table test1601_detach_permanently_lazy.test_name_reuse;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8528 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0eed4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003296ac6b 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032968e1f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965c79 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 09:15:21.998214 [ 45838 ] {} TCPHandler: Code: 60. DB::Exception: Table test1601_detach_permanently_lazy.test_name_reuse does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8528 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0eed4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003296ac6b 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032968e1f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965c79 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 09:15:22.102494 [ 45838 ] {d60b4f5f-7ba0-4640-89fc-cfec60615680} executeQuery: Code: 60. DB::Exception: Table test1601_detach_permanently_lazy.test_name_reuse does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59946) (comment: 01601_detach_permanently.sql) (query 108, line 169) (in query: drop table test1601_detach_permanently_lazy.test_name_reuse;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8528 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0eed4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003296ac6b 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032968e1f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965c79 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 09:15:22.108902 [ 45838 ] {} TCPHandler: Code: 60. DB::Exception: Table test1601_detach_permanently_lazy.test_name_reuse does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8528 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0eed4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003296ac6b 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032968e1f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965c79 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 09:15:22.400641 [ 45838 ] {26caedf9-bad5-4bfd-95ff-280582c9139c} executeQuery: Code: 57. DB::Exception: Table `test1601_detach_permanently_lazy`.`test_name_reuse` already exists (detached permanently). (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59946) (comment: 01601_detach_permanently.sql) (query 111, line 174) (in query: RENAME TABLE test1601_detach_permanently_lazy.test_name_rename_attempt TO test1601_detach_permanently_lazy.test_name_reuse;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:412: DB::DatabaseOnDisk::checkMetadataFilenameAvailabilityUnlocked(String const&) const @ 0x000000002f86ff89 5. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:391: DB::DatabaseOnDisk::checkMetadataFilenameAvailability(String const&) const @ 0x000000002f86f449 6. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:482: DB::DatabaseOnDisk::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x000000002f87259b 7. ./build_docker/./src/Databases/DatabaseLazy.cpp:109: DB::DatabaseLazy::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x000000002fa4c50a 8. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a037d4 9. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:15:22.407435 [ 45838 ] {} TCPHandler: Code: 57. DB::Exception: Table `test1601_detach_permanently_lazy`.`test_name_reuse` already exists (detached permanently). (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:412: DB::DatabaseOnDisk::checkMetadataFilenameAvailabilityUnlocked(String const&) const @ 0x000000002f86ff89 5. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:391: DB::DatabaseOnDisk::checkMetadataFilenameAvailability(String const&) const @ 0x000000002f86f449 6. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:482: DB::DatabaseOnDisk::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x000000002f87259b 7. ./build_docker/./src/Databases/DatabaseLazy.cpp:109: DB::DatabaseLazy::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x000000002fa4c50a 8. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a037d4 9. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:15:22.646884 [ 45838 ] {23343174-5037-4ce2-9eb1-2c5d2c3173c6} InterpreterCreateQuery: ATTACH TABLE query with full table definition is not recommended: use either ATTACH TABLE test_name_reuse; to attach existing table or CREATE TABLE test_name_reuse
; to create new table or ATTACH TABLE test_name_reuse FROM '/path/to/data/'
; to create new table and attach data. 2025.06.13 09:15:22.975656 [ 45838 ] {33a5ea71-f994-4ee3-b746-900da5eef92a} executeQuery: Code: 60. DB::Exception: Table test1601_detach_permanently_lazy.test_name_reuse does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59946) (comment: 01601_detach_permanently.sql) (query 121, line 189) (in query: DETACH table test1601_detach_permanently_lazy.test_name_reuse PERMANENTLY;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8528 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0eed4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003296ac6b 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032968e1f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965c79 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 09:15:22.981874 [ 45838 ] {} TCPHandler: Code: 60. DB::Exception: Table test1601_detach_permanently_lazy.test_name_reuse does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8528 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0eed4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003296ac6b 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032968e1f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965c79 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 09:15:23.528629 [ 45838 ] {ce83a495-4436-41da-ad86-ec049c26494c} executeQuery: Code: 60. DB::Exception: Table test1601_detach_permanently_lazy.test_name_reuse does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59946) (comment: 01601_detach_permanently.sql) (query 131, line 203) (in query: DETACH table test1601_detach_permanently_lazy.test_name_reuse PERMANENTLY;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8528 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0eed4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003296ac6b 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032968e1f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965c79 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 09:15:23.534791 [ 45838 ] {} TCPHandler: Code: 60. DB::Exception: Table test1601_detach_permanently_lazy.test_name_reuse does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8528 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0eed4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003296ac6b 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032968e1f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965c79 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 09:15:23.914429 [ 45838 ] {86333ec1-ab77-4467-98ca-70d67ebb86ba} executeQuery: Code: 219. DB::Exception: Cannot drop: Cannot remove directory /var/lib/clickhouse/data/test1601_detach_permanently_lazy/: , errno: 39, strerror: Directory not empty. Probably database contain some detached tables or metadata leftovers from Ordinary engine. If you want to remove all data anyway, try to attach database back and drop it again with enabled force_remove_data_recursively_on_drop setting. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59946) (comment: 01601_detach_permanently.sql) (query 137, line 212) (in query: DROP DATABASE test1601_detach_permanently_lazy;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x0000000012877c0a 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:611: DB::DatabaseOnDisk::drop(std::shared_ptr) @ 0x000000002f87a9d4 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:627: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031a02ffb 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032977eb2 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032969430 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965ed2 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:15:23.921101 [ 45838 ] {} TCPHandler: Code: 219. DB::Exception: Cannot drop: Cannot remove directory /var/lib/clickhouse/data/test1601_detach_permanently_lazy/: , errno: 39, strerror: Directory not empty. Probably database contain some detached tables or metadata leftovers from Ordinary engine. If you want to remove all data anyway, try to attach database back and drop it again with enabled force_remove_data_recursively_on_drop setting. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x0000000012877c0a 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:611: DB::DatabaseOnDisk::drop(std::shared_ptr) @ 0x000000002f87a9d4 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:627: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031a02ffb 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032977eb2 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032969430 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032965ed2 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000329654d3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:15:31.011647 [ 45838 ] {01600_log_queries_with_extensive_info_004_err} executeQuery: Code: 32. DB::Exception: Attempt to read after eof: while converting '' to Int32. (ATTEMPT_TO_READ_AFTER_EOF) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37214) (comment: 01600_log_queries_with_extensive_info.sh) (query 1, line 1) (in query: select k from test_log_queries.logtable where i > ''), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/IO/VarInt.cpp:13: DB::throwReadAfterEOF() @ 0x000000001f8f6d6c 5. ./src/IO/ReadHelpers.h:537: void DB::readIntTextUnsafe(long&, DB::ReadBuffer&) @ 0x000000002f64a5f1 6. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:30: DB::SerializationNumber::deserializeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x000000002f64a128 7. DB::SimpleTextSerialization::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000008dcf546 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:578: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000033680634 9. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000003367a53e 10. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f126fa7 11. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f0dd794 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301087b6 18. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000030104ffd 19. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003ba17e0c 20. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003c039728 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000032a99dea 22. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032b178a2 23. ./build_docker/./src/Planner/Planner.cpp:1629: DB::Planner::buildPlanForQueryNode() @ 0x0000000032aff807 24. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 2025.06.13 09:15:31.023774 [ 45838 ] {} TCPHandler: Code: 32. DB::Exception: Attempt to read after eof: while converting '' to Int32. (ATTEMPT_TO_READ_AFTER_EOF), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/IO/VarInt.cpp:13: DB::throwReadAfterEOF() @ 0x000000001f8f6d6c 5. ./src/IO/ReadHelpers.h:537: void DB::readIntTextUnsafe(long&, DB::ReadBuffer&) @ 0x000000002f64a5f1 6. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:30: DB::SerializationNumber::deserializeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x000000002f64a128 7. DB::SimpleTextSerialization::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000008dcf546 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:578: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000033680634 9. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000003367a53e 10. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f126fa7 11. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f0dd794 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301087b6 18. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000030104ffd 19. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003ba17e0c 20. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003c039728 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000032a99dea 22. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032b178a2 23. ./build_docker/./src/Planner/Planner.cpp:1629: DB::Planner::buildPlanForQueryNode() @ 0x0000000032aff807 24. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 2025.06.13 09:16:12.018898 [ 410 ] {} CgroupsReader: Cannot find 'kernel' in '/sys/fs/cgroup/memory.stat' (skipped 5899 similar messages) 2025.06.13 09:16:37.723556 [ 45838 ] {9fbce080-0752-4abd-a825-926e8c78289f} executeQuery: Code: 286. DB::Exception: Another quorum insert has been already started. (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45720) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r7 SELECT 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1105: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000003a30a17f 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000003a301d3b 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()::operator()() const @ 0x000000003a3019c9 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000003a30131f 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a2c866d 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a29d717 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000003a2c67d4 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e76f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d33c 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 09:16:37.723672 [ 46930 ] {d736ca2b-b6fb-4194-b1a5-4dc4d608dc00} executeQuery: Code: 286. DB::Exception: Another quorum insert has been already started. (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45758) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1105: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000003a30a17f 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000003a301d3b 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()::operator()() const @ 0x000000003a3019c9 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000003a30131f 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a2c866d 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a29d717 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000003a2c67d4 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e76f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d33c 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 09:16:37.723672 [ 46931 ] {1684fc09-fdb9-4237-a6d1-cb9ced60d29a} executeQuery: Code: 286. DB::Exception: Another quorum insert has been already started. (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45766) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1105: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000003a30a17f 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000003a301d3b 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()::operator()() const @ 0x000000003a3019c9 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000003a30131f 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a2c866d 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a29d717 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000003a2c67d4 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e76f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d33c 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 09:16:37.724253 [ 46929 ] {8373ce7a-8d4b-420c-99a3-cffc1479f2e9} executeQuery: Code: 286. DB::Exception: Another quorum insert has been already started. (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45756) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1105: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000003a30a17f 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000003a301d3b 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()::operator()() const @ 0x000000003a3019c9 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000003a30131f 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a2c866d 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a29d717 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000003a2c67d4 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e76f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d33c 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 09:16:37.740440 [ 46934 ] {c2cbe3e4-d0f2-4d1d-9361-93a45f4bb78f} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_0_0_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45796) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r4 SELECT 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:37.749479 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Another quorum insert has been already started. (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1105: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000003a30a17f 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000003a301d3b 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()::operator()() const @ 0x000000003a3019c9 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000003a30131f 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a2c866d 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a29d717 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000003a2c67d4 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e76f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d33c 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:37.754624 [ 46931 ] {} TCPHandler: Code: 286. DB::Exception: Another quorum insert has been already started. (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1105: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000003a30a17f 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000003a301d3b 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()::operator()() const @ 0x000000003a3019c9 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000003a30131f 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a2c866d 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a29d717 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000003a2c67d4 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e76f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d33c 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:37.756401 [ 46929 ] {} TCPHandler: Code: 286. DB::Exception: Another quorum insert has been already started. (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1105: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000003a30a17f 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000003a301d3b 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()::operator()() const @ 0x000000003a3019c9 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000003a30131f 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a2c866d 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a29d717 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000003a2c67d4 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e76f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d33c 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:37.756543 [ 45838 ] {} TCPHandler: Code: 286. DB::Exception: Another quorum insert has been already started. (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1105: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000003a30a17f 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000003a301d3b 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()::operator()() const @ 0x000000003a3019c9 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000003a30131f 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a2c866d 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a29d717 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000003a2c67d4 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e76f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d33c 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:37.763092 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_0_0_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:38.334380 [ 46932 ] {9d5e76ee-6b9f-4f08-a99d-c71566806255} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_5_5_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45846) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:38.355643 [ 46932 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_5_5_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:38.380437 [ 46934 ] {d5e1ebc7-37be-434f-9952-1671984a5197} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_5_5_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45864) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:38.396995 [ 46933 ] {857b052b-40df-42e8-9b3a-9488e055dfbc} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_5_5_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45860) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:38.397132 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_5_5_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:38.414708 [ 46933 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_5_5_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:39.270950 [ 46933 ] {2cd7ded2-e803-43bd-a0f1-96ba6f92a99f} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_6_6_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45996) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:39.276239 [ 45838 ] {268cc12c-1896-424a-8095-4afa36bb72bd} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_6_6_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46008) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:39.304767 [ 46930 ] {7eebb94c-0885-4444-a5ee-561747ab2302} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_6_6_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45984) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r7 SELECT 2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:39.306657 [ 46933 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_6_6_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:39.310498 [ 46927 ] {ccea52b9-5bec-498b-9942-c2280cf5759a} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_6_6_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46018) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r4 SELECT 2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:39.321377 [ 45838 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_6_6_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:39.330107 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_6_6_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:39.330677 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_6_6_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:39.360012 [ 46928 ] {f6438158-3ac6-4fbe-9629-4872ccfad68c} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_6_6_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46022) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:39.382024 [ 46928 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_6_6_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:39.411546 [ 46929 ] {ba62fa0a-3c1f-4aca-8ad2-5ce0b8219787} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_6_6_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r1 r10 r4 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46024) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:39.416817 [ 46932 ] {051b3659-8780-4b22-b40e-0cff834e8491} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_6_6_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r1 r10 r4 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46034) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:39.435317 [ 46929 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_6_6_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r1 r10 r4 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:39.437031 [ 46932 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_6_6_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r1 r10 r4 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:40.065511 [ 46932 ] {248f4ca1-a27b-4ef2-9453-33387eb6e803} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_7_7_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46132) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 3), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:40.085316 [ 46932 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_7_7_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:40.891758 [ 46934 ] {2666e277-e19b-4b5e-b902-a92bd1f27564} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_8_8_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46260) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r4 SELECT 4), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:40.909829 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_8_8_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:40.915423 [ 45838 ] {3d6ca7bf-f3ee-4dc7-a6ec-b8dd4963ea5b} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_8_8_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46278) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r7 SELECT 4), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:40.925777 [ 46927 ] {4f79f58a-c16c-4720-bfd0-14437fc770db} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_8_8_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46284) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 4), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:40.939016 [ 45838 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_8_8_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:40.946518 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_8_8_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:40.970624 [ 46929 ] {c9e08de8-b48a-461d-b178-f1e2648db239} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_8_8_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46292) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 4), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:40.970933 [ 43368 ] {2ea549eb-8dc5-4929-9adb-3cb1352a2d75} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_8_8_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46270) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 4), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:40.988219 [ 46931 ] {51df9178-69a6-4ea4-862d-beb0d62a5e9f} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_8_8_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46296) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 4), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:40.991826 [ 43368 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_8_8_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:41.002308 [ 46929 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_8_8_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:41.020955 [ 46931 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_8_8_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:41.716525 [ 46930 ] {c443e14c-6712-432f-b80c-ab87dcd9c90a} executeQuery: Code: 286. DB::Exception: Another quorum insert has been already started. (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46378) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r10 SELECT 5), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1105: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000003a30a17f 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000003a301d3b 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()::operator()() const @ 0x000000003a3019c9 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000003a30131f 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a2c866d 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a29d717 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000003a2c67d4 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e76f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d33c 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 09:16:41.741044 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Another quorum insert has been already started. (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1105: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000003a30a17f 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000003a301d3b 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()::operator()() const @ 0x000000003a3019c9 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000003a30131f 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a2c866d 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a29d717 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000003a2c67d4 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e76f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d33c 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:41.798532 [ 43368 ] {56eb817c-047f-4205-8ec2-d6a5fd72ea1d} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_9_9_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46406) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 5), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:41.823558 [ 43368 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_9_9_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:41.928621 [ 46934 ] {b04fa6ac-3563-40b1-a147-668f6115aaaa} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_9_9_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46408) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r4 SELECT 5), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:41.947215 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_9_9_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:42.578718 [ 46934 ] {966808ca-ddf8-4254-a0f8-b11a82c6d02e} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_11_11_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46528) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 6), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:42.600643 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_11_11_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:42.602402 [ 46927 ] {369a5646-5ccd-492f-9d15-2d61a6f235a8} executeQuery: Code: 286. DB::Exception: Another quorum insert has been already started. (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46514) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 6), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1105: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000003a30a17f 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000003a301d3b 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()::operator()() const @ 0x000000003a3019c9 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000003a30131f 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a2c866d 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a29d717 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000003a2c67d4 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e76f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d33c 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 09:16:42.624169 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Another quorum insert has been already started. (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1105: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000003a30a17f 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000003a301d3b 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()::operator()() const @ 0x000000003a3019c9 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000003a30131f 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a2c866d 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a29d717 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000003a2c67d4 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e76f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d33c 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:42.631125 [ 46931 ] {2c099b2b-1a30-4132-850c-64a598a159a0} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_11_11_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46552) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r7 SELECT 6), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:42.631140 [ 46929 ] {9298c560-18fc-4ee8-9ab4-6763a916e935} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_11_11_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46538) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 6), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:42.651726 [ 46929 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_11_11_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:42.652098 [ 46931 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_11_11_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:42.678270 [ 46930 ] {b05da83e-6c29-46dc-bf00-6b26909cd5ab} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_11_11_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46566) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 6), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:42.687802 [ 46933 ] {4f123294-a26d-4d86-8145-8552cbdfc891} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_11_11_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46580) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 6), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:42.695478 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_11_11_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:42.710643 [ 46933 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_11_11_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:42.742416 [ 47191 ] {fd9ecb97-ef63-49b3-a309-bdd9b6807e8b} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_11_11_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46588) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r10 SELECT 6), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:42.781422 [ 47191 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_11_11_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:43.603055 [ 46931 ] {7d593353-9f11-4dd5-969f-9d75a1485a75} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_13_13_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44736) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 7), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:43.618590 [ 46934 ] {b8373cf0-e5b2-4abe-a042-6945d899b34a} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_13_13_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44756) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r4 SELECT 7), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:43.624161 [ 46931 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_13_13_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:43.625338 [ 46930 ] {833cf8fa-e50a-4874-9c6a-16c8ef0c94f0} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_13_13_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44740) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 7), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:43.628943 [ 46933 ] {ff142945-f47e-40cc-bcae-37a0454fe449} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_13_13_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44750) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 7), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:43.645755 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_13_13_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:43.647386 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_13_13_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:43.655568 [ 46933 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_13_13_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:43.694162 [ 43368 ] {7e38c78d-1451-4471-b86c-867b96d9d0a4} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_13_13_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44764) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 7), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:43.719250 [ 43368 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_13_13_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:43.758204 [ 46927 ] {e5a7a4bf-a782-40aa-90f0-da21a2c51b33} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_13_13_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r1 r10 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44778) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 7), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:43.777159 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_13_13_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r1 r10 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:43.777286 [ 45838 ] {bd5541e5-8220-451d-88bf-04d0fe15a4e8} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_13_13_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r1 r10 r7 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44770) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r7 SELECT 7), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:43.796379 [ 45838 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_13_13_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r1 r10 r7 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:44.408209 [ 47191 ] {848c253e-7b1d-4a1a-bc15-f673f4a0ab21} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_14_14_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44914) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r10 SELECT 8), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:44.430138 [ 47191 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_14_14_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:45.217773 [ 46930 ] {34c6e98e-2acd-46a6-bb2d-a2864419d990} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_15_15_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44988) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r4 SELECT 9), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:45.239416 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_15_15_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:45.252190 [ 46933 ] {18f10f11-47bc-4872-8dcd-294c66bfc465} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_15_15_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44990) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 9), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:45.263309 [ 46934 ] {a30b1501-b55c-483f-998c-78ceba1595a2} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_15_15_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44998) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 9), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:45.279784 [ 46933 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_15_15_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:45.288721 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_15_15_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:45.317281 [ 43368 ] {3db3f068-2e75-4c3e-8e4e-9fa1c2a835af} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_15_15_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45004) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 9), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:45.319411 [ 45838 ] {c4a548d4-891c-4989-b0f2-4b297781a034} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_15_15_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45008) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 9), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:45.342938 [ 45838 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_15_15_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:45.343457 [ 43368 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_15_15_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:45.371315 [ 46927 ] {4eab62e6-12fc-428c-af45-d8260e549066} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_15_15_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r7 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45016) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 9), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:45.390812 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_15_15_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r7 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:45.934258 [ 46927 ] {365d914b-32ca-440f-9fd9-1bd300881660} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_16_16_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45122) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 9), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:45.957271 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_16_16_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:46.032867 [ 46929 ] {60eb8da6-7f61-4bdc-9a8d-5a3a3bf65de9} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_16_16_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45128) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r7 SELECT 10), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:46.062041 [ 46929 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_16_16_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:46.076152 [ 46932 ] {09b5fa5b-fe88-4ad8-a83c-d204b9896d5f} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_16_16_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45132) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r10 SELECT 10), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:46.108098 [ 46932 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_16_16_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:46.913076 [ 46933 ] {5e2b8a89-ae4b-4ca7-bba8-79951a95162a} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_17_17_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45260) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r4 SELECT 11), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:46.914249 [ 46934 ] {777e3497-d3b7-4add-8878-02316da1fb35} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_17_17_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45264) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 11), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:46.929744 [ 46927 ] {d0e555a8-e177-4278-bb8c-665814d98a48} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_17_17_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45272) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 11), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:46.939688 [ 46933 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_17_17_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:46.939688 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_17_17_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:46.952912 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_17_17_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:47.574353 [ 47191 ] {6cc3072a-cf1d-47c5-a22e-9d85240a82fb} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_18_18_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45364) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 11), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:47.598846 [ 47191 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_18_18_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:47.637764 [ 46931 ] {10da40eb-6be8-4155-8014-f9ebf7a69519} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_18_18_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45376) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 12), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:47.641629 [ 46930 ] {6791f480-cd9a-47f1-bd58-30c1679e21e4} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_18_18_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45392) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 12), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:47.660079 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_18_18_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:47.667707 [ 46931 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_18_18_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:47.708992 [ 43368 ] {42344947-f4f9-40da-a3a7-a5acb42a311a} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_18_18_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45408) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r7 SELECT 12), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:47.728932 [ 43368 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_18_18_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:47.751796 [ 46934 ] {1b27b435-baf7-4cb9-b7a2-a7b52adfd4e8} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_18_18_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45414) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r10 SELECT 12), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:47.773180 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_18_18_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:48.442124 [ 45838 ] {3de55683-66a0-4b50-a62b-0b8816b52096} executeQuery: Code: 286. DB::Exception: Another quorum insert has been already started. (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45498) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 13), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1105: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000003a30a17f 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000003a301d3b 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()::operator()() const @ 0x000000003a3019c9 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000003a30131f 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a2c866d 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a29d717 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000003a2c67d4 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e76f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d33c 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 09:16:48.468034 [ 45838 ] {} TCPHandler: Code: 286. DB::Exception: Another quorum insert has been already started. (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1105: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000003a30a17f 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000003a301d3b 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()::operator()() const @ 0x000000003a3019c9 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000003a30131f 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a2c866d 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a29d717 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000003a2c67d4 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e76f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d33c 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:48.517185 [ 46933 ] {8315aade-7331-46ac-b24a-17ac158656e0} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_19_19_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45502) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 13), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:48.523574 [ 46934 ] {92068369-0934-4d1f-be96-f9457647c92d} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_19_19_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45506) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r4 SELECT 13), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:48.538720 [ 46933 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_19_19_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:48.543599 [ 46927 ] {f1352860-07e6-46ce-ae83-01abc71efdfc} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_19_19_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45514) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 13), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:48.544807 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_19_19_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:48.573763 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_19_19_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:48.595348 [ 46930 ] {83ec31ae-2093-478e-a663-a8afad857a98} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_19_19_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45530) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 12), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:48.623229 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_19_19_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:48.674440 [ 45838 ] {3644959d-9c85-483e-8039-17b2f9f3d733} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_19_19_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45546) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r7 SELECT 13), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:48.695735 [ 45838 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_19_19_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:48.727284 [ 46929 ] {abeb9cb7-0120-4b10-b55d-843dcae82158} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_19_19_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r2 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45562) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 13), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:48.747633 [ 46929 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_19_19_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r2 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:48.772836 [ 46932 ] {c6edb6f8-ac7c-46cb-acdc-a9be04f8d490} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_19_19_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r1 r2 r8 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45570) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 13), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:48.794872 [ 46932 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_19_19_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r1 r2 r8 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:49.413657 [ 47191 ] {672a664b-f3cb-4ba0-bd6e-5e11f0968659} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_21_21_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45676) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r10 SELECT 14), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:49.435405 [ 47191 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_21_21_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:49.482133 [ 43368 ] {3db9cd52-05db-45e2-b6c9-742ec25b3b7e} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_21_21_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45678) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 14), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:49.501043 [ 43368 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_21_21_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:49.634098 [ 46933 ] {8131b7b6-e0d5-4142-ad89-60fce61bf196} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_21_21_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r10 r6 r8 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45684) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 13), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:49.654430 [ 46933 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_21_21_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r10 r6 r8 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:50.229805 [ 45838 ] {6af946bc-8423-4153-8ed0-1bf6d278ffdb} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_22_22_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45766) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 15), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:50.231634 [ 46934 ] {4246901d-24d7-4ca7-91e5-d8fa8771966f} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_22_22_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45776) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 15), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:50.248630 [ 47191 ] {368e4135-ddf8-4877-8f28-b2e4a28ee982} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_22_22_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45788) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r4 SELECT 15), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:50.254227 [ 45838 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_22_22_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:50.255464 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_22_22_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:50.269332 [ 47191 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_22_22_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:50.352310 [ 46931 ] {dea5efae-ab65-4ad1-ace5-aadc015dbc25} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_22_22_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45794) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r7 SELECT 15), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:50.370553 [ 46931 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_22_22_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:51.044488 [ 46933 ] {738959a5-a66c-455d-9510-86b844c9427f} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_23_23_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45882) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 16), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:51.069352 [ 46933 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_23_23_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:51.090932 [ 46929 ] {28c6a217-807e-4707-94c1-4bd659b62bd6} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_23_23_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45914) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 16), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:51.101008 [ 43368 ] {05b0d211-c313-49d1-9dc3-3d357b2812e4} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_23_23_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45884) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 16), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:51.107317 [ 46929 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_23_23_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:51.119432 [ 46927 ] {56618b22-c753-47b0-8d08-a6727d627329} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_23_23_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45898) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r10 SELECT 16), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:51.124638 [ 43368 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_23_23_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:51.150332 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_23_23_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:51.892296 [ 45838 ] {cac70e3f-2a7f-48d9-96eb-3f89c4db4919} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_24_24_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46016) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 17), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:51.901302 [ 46931 ] {f98b85d4-1f32-4570-8a19-57ddf153705b} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_24_24_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46050) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 17), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:51.901462 [ 46934 ] {2c761dff-7fac-4f17-bca9-f44d9cba02c1} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_24_24_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46028) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r4 SELECT 17), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:51.921855 [ 47191 ] {ed1d1665-8a3a-41d2-bdce-b85a4ef493f9} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_24_24_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46034) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 16), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:51.922207 [ 45838 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_24_24_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:51.931218 [ 46931 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_24_24_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:51.937889 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_24_24_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:51.944171 [ 46932 ] {07647969-e490-4fb9-ba04-c7e9a4dcfe40} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_24_24_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46054) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r7 SELECT 17), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:51.948920 [ 47191 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_24_24_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:51.976103 [ 46932 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_24_24_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:52.674022 [ 45838 ] {fe3c4bd9-9ccf-41fd-84fe-97c7eb6f4c69} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_25_25_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46162) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 18), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:52.693350 [ 45838 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_25_25_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:52.700774 [ 46932 ] {336c54d4-456d-4c38-8491-1cc0150949e7} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_25_25_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46176) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 18), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:52.719154 [ 46932 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_25_25_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:52.742571 [ 46934 ] {354df86c-4777-4999-ad1e-2355d184686a} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_25_25_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46188) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 18), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:52.744838 [ 46930 ] {12d29b61-c152-418f-88a4-9f2cba3da45b} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_25_25_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46196) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r10 SELECT 18), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:52.774690 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_25_25_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:52.782743 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_25_25_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:53.513193 [ 43368 ] {3bf3e40e-379d-42b3-9c00-b7640c88e495} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_26_26_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45160) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r7 SELECT 19), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:53.529756 [ 45838 ] {0491d6db-6a0d-4950-a22c-6e726cff50a1} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_26_26_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45174) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 19), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:53.532954 [ 46930 ] {bb39d6ad-c547-42ef-92fc-c79a41574be4} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_26_26_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45188) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 19), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:53.539753 [ 43368 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_26_26_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:53.549686 [ 47191 ] {99941033-472d-4e93-8b66-b4c1e4bc4706} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_26_26_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45184) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 18), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:53.553222 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_26_26_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:53.562537 [ 45838 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_26_26_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:53.570945 [ 47191 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_26_26_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:53.572919 [ 46931 ] {06eae969-c62e-4684-89dd-8362564b5b37} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_26_26_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45196) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r4 SELECT 19), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:53.595055 [ 46931 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_26_26_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:54.338677 [ 46927 ] {ef7622c8-57d1-408c-8512-e09bf23de193} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_27_27_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45300) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 20), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:54.350066 [ 46929 ] {0cc2994f-5e3e-46e4-b8eb-3234b5dbdba1} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_27_27_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45316) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 20), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:54.363290 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_27_27_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:54.382607 [ 46929 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_27_27_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:54.406694 [ 46931 ] {1c475a87-3627-456f-8318-aa1718c3aa8c} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_27_27_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45326) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 20), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:54.430254 [ 46931 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_27_27_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:54.432439 [ 46932 ] {4723b458-373f-4138-8e16-a845199228b4} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_27_27_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45334) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r10 SELECT 20), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:54.450077 [ 46932 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_27_27_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:54.564826 [ 43368 ] {217dca8e-7387-4fd8-b51c-2e47a43dcbd9} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_27_27_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45348) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 20), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:54.583583 [ 43368 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_27_27_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:54.631774 [ 45838 ] {a916af6b-bf9f-4ccf-bdd2-f4be7e72a8df} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_27_27_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r3 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45360) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r7 SELECT 20), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:54.650648 [ 46930 ] {b84bc01d-db62-4b45-b0e1-0cef2160e1fd} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_27_27_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r3 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45394) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 20), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:54.650841 [ 47191 ] {8c06651a-553c-4a7a-9089-96a11306fa29} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_27_27_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r3 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45386) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r4 SELECT 20), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:54.651741 [ 45838 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_27_27_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r3 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:54.653177 [ 46934 ] {1a64faee-7a83-4f12-913a-3796ec8e4f2d} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_27_27_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r3 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45376) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 19), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:54.673177 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_27_27_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r3 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:54.675873 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_27_27_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r3 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:54.678119 [ 47191 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_27_27_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r3 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:55.506603 [ 46933 ] {4dec77de-48e3-499c-97dd-107f2038a445} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_28_28_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45512) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 21), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:55.512293 [ 46931 ] {35908918-7b40-41ba-9b90-53d6fffee236} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_28_28_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45528) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 21), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:55.512317 [ 46929 ] {683ff56f-4b8a-4941-b837-368fff6ace18} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_28_28_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45526) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 21), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:55.530722 [ 46933 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_28_28_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:55.531210 [ 46929 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_28_28_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:55.537912 [ 46931 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_28_28_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:55.567199 [ 46932 ] {8d851172-6275-4359-b07e-130f4ea61586} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_28_28_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45540) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r10 SELECT 21), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:55.590491 [ 46932 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_28_28_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:55.607120 [ 43368 ] {2b929336-0049-43f8-bf1b-869cd356f7b4} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_28_28_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45544) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 21), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:55.634601 [ 43368 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_28_28_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:55.670055 [ 45838 ] {19e102ee-a171-4ecf-a6f9-82110977575f} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_28_28_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r1 r4 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45556) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r4 SELECT 21), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:55.690575 [ 45838 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_28_28_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r1 r4 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:55.702992 [ 46934 ] {bd235042-0d14-465a-8ffc-0c1759655158} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_28_28_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r1 r4 r6 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45570) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 20), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:55.721414 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_28_28_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r1 r4 r6 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:56.332703 [ 46931 ] {72b1a2dd-bfaa-417c-8cd0-ca84ca9a91a1} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_29_29_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45680) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 22), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:56.341568 [ 46932 ] {db7103d2-c57e-468a-971b-5977ee206eb0} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_29_29_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45688) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r7 SELECT 22), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:56.356715 [ 46931 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_29_29_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:56.369359 [ 46932 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_29_29_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:56.572505 [ 45838 ] {5aff51b2-cfeb-47f5-96ee-a197a647a178} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_29_29_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r5 r6 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45708) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 22), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:56.578777 [ 46934 ] {f7f83a27-e70b-4755-981f-9d491775755d} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_29_29_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r2 r5 r6 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45724) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 22), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:56.594529 [ 45838 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_29_29_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r5 r6 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:56.596489 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_29_29_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r2 r5 r6 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:57.195391 [ 46930 ] {999d5405-5ea5-4e31-8bcc-804a3e50b56f} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_30_30_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45810) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 23), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:57.213774 [ 45838 ] {16c7c98a-2e76-448b-aa20-a1d88afd1897} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_30_30_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45814) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r10 SELECT 23), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:57.217045 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_30_30_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:57.235420 [ 45838 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_30_30_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:57.302279 [ 46933 ] {2805e311-f194-4725-b4c7-ec43679f82f5} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_30_30_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45820) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r4 SELECT 23), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:57.302454 [ 46927 ] {dd0dc053-11b3-41ce-9f67-8c0f94780975} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_30_30_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45828) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 22), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:57.326964 [ 46933 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_30_30_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:57.329016 [ 46929 ] {8b123369-76df-473f-9107-da48fc0c4bc8} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_30_30_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45830) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 23), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:57.336116 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_30_30_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:57.361765 [ 46929 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_30_30_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:57.396150 [ 46932 ] {e601f404-d16b-43a6-9b43-c6d55b042037} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_30_30_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45850) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r7 SELECT 23), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:57.414558 [ 46932 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_30_30_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:57.456879 [ 46931 ] {296610a0-92cd-41f4-b1d0-c3e2d858037e} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_30_30_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r4 r5 r6 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45842) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 23), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:57.479207 [ 46931 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_30_30_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r4 r5 r6 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:58.164929 [ 46931 ] {d3a5d1b7-a859-47f7-a155-5879b1ca1987} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_31_31_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45962) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 24), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:58.197261 [ 46931 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_31_31_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:58.197823 [ 46932 ] {144f8d16-53bd-448a-a445-6c23d6acdc1c} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_31_31_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45966) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 24), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:58.227194 [ 46932 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_31_31_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:58.304345 [ 43368 ] {8f5cf3e3-7252-4631-b38c-c96dc660622d} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_31_31_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r1 r10 r7 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45978) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 24), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:58.311962 [ 45838 ] {c6a7ee01-43a7-4a01-9ad3-248361959466} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_31_31_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r1 r10 r7 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45986) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r10 SELECT 24), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:58.332436 [ 45838 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_31_31_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r1 r10 r7 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:58.332942 [ 43368 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_31_31_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r1 r10 r7 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:58.910117 [ 46931 ] {fd8c06f4-7f9f-45f2-9eae-fda2168e2862} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_32_32_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46066) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r4 SELECT 25), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:58.930702 [ 46931 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_32_32_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:58.978417 [ 46930 ] {65486e0e-3a86-40c5-ac8a-a1613c574149} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_32_32_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46070) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 24), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:58.984909 [ 46927 ] {067fb0bc-c262-4d2a-8baf-3e9ca5ee595f} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_32_32_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46086) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 25), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:58.985404 [ 46933 ] {a77b710b-65a4-43d7-8b15-ad787db06d0a} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_32_32_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46090) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r7 SELECT 25), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:59.004219 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_32_32_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:59.009993 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_32_32_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:59.011858 [ 46933 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_32_32_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:59.072671 [ 46932 ] {a4c1ec09-d75f-4364-96f0-5626a92783ad} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_32_32_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46094) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 25), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:59.096884 [ 46932 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_32_32_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:59.850905 [ 46934 ] {341b6e3c-1b01-4c6d-acec-8784c69ecaf7} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_33_33_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46196) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 26), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:59.857496 [ 47191 ] {d1ffdff1-8654-4a73-80a5-289c8cd5e78b} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_33_33_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46210) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 26), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:59.874471 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_33_33_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:59.875198 [ 47191 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_33_33_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:59.898381 [ 46929 ] {1cf4ba1f-e372-4f1a-843e-0d8a9bfe565b} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_33_33_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46212) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r10 SELECT 26), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:59.928019 [ 46929 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_33_33_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:16:59.964384 [ 46931 ] {269f7655-5e56-4f63-a8b2-850cc72e4713} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_33_33_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46224) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r4 SELECT 26), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:59.964927 [ 46932 ] {a8dadc98-88f6-4432-b4cf-617884e3dcb0} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_33_33_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46226) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 26), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:16:59.998975 [ 46932 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_33_33_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:00.007021 [ 46931 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_33_33_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:00.039850 [ 45838 ] {cbd8319d-6cb1-4b6c-bb3e-55fb929e973e} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_33_33_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r3 r8 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46232) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 25), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:00.058649 [ 45838 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_33_33_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r3 r8 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:00.751005 [ 46934 ] {92d641ee-d716-44d9-9162-07a82e9f97c2} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_34_34_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46334) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 27), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:00.750299 [ 43368 ] {f97b6948-f0d7-4887-b387-1b6f5d7dbb0f} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_34_34_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46332) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 27), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:00.772156 [ 43368 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_34_34_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:00.775122 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_34_34_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:00.870433 [ 47191 ] {b8621399-d984-49b8-9fa9-ea2fcb48649b} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_34_34_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46342) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 27), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:00.894745 [ 47191 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_34_34_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:00.951406 [ 46931 ] {ccd3f400-85ac-4a15-8085-9729bdaefa24} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_34_34_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r4 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46350) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 27), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:00.970758 [ 46931 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_34_34_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r4 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:01.011043 [ 46932 ] {dd72a2c5-3bc4-453e-aaa3-e03665c5695f} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_34_34_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r2 r4 r6 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46362) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r10 SELECT 27), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:01.030079 [ 46932 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_34_34_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r2 r4 r6 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:01.569384 [ 46934 ] {9e109cad-9116-47ec-a4b1-a4a8d979811b} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_35_35_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46468) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 28), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:01.593831 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_35_35_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:01.626729 [ 47191 ] {65608ed0-8bab-4b55-b198-a58699b6364f} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_35_35_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46482) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r4 SELECT 28), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:01.647382 [ 47191 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_35_35_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:01.770034 [ 46933 ] {1136baf0-f6be-4414-b0e3-c8e346150059} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_35_35_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46496) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 27), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:01.789587 [ 46933 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_35_35_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:01.815561 [ 46927 ] {505b4a2b-0ae6-4548-8f3d-2305267868cd} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_35_35_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46512) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 28), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:01.836491 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_35_35_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:01.858433 [ 43368 ] {7c59ad05-c081-4685-b38d-5c8707d582a8} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_35_35_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r10 r8 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46522) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 28), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:01.881940 [ 43368 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_35_35_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r10 r8 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:02.572359 [ 46933 ] {4324e6f0-e388-4a87-b262-941df7df6ce0} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_36_36_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46616) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 29), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:02.586347 [ 43368 ] {51aba5dd-0ff1-4e61-beaa-45589fd484db} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_36_36_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46618) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 29), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:02.603771 [ 46933 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_36_36_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:02.611398 [ 43368 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_36_36_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:02.616572 [ 46927 ] {7dae0c3b-ac04-4ce9-8487-ad533006a1fe} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_36_36_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46626) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r10 SELECT 29), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:02.642404 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_36_36_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:02.649849 [ 46932 ] {61567c72-44dd-4cde-8ba9-6f1633b46776} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_36_36_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46636) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r4 SELECT 29), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:02.674537 [ 46932 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_36_36_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:02.722246 [ 46929 ] {2517ff9a-fb34-45f6-a0bd-96dd11e821ee} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_36_36_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r1 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46648) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 29), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:02.742662 [ 46929 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_36_36_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r1 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:03.394826 [ 46934 ] {f35d94e9-78d1-4408-840f-a56d2dfbca54} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_37_37_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53280) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 29), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:03.423079 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_37_37_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:03.457304 [ 43368 ] {8177a7d6-5a6e-4308-aad3-796610d87de5} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_37_37_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53282) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 30), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:03.480219 [ 43368 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_37_37_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:03.542715 [ 46929 ] {632847d4-8b04-4e98-aa0d-76c72099db77} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_37_37_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r1 r5 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53290) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 30), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:03.564728 [ 46929 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_37_37_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r1 r5 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:04.118576 [ 46932 ] {c755b6be-b2d9-4ca5-be3d-060ada263c5e} executeQuery: Code: 286. DB::Exception: Another quorum insert has been already started. (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53364) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r8 SELECT 31), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1105: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000003a30a17f 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000003a301d3b 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()::operator()() const @ 0x000000003a3019c9 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000003a30131f 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a2c866d 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a29d717 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000003a2c67d4 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e76f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d33c 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 09:17:04.138857 [ 46932 ] {} TCPHandler: Code: 286. DB::Exception: Another quorum insert has been already started. (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1105: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000003a30a17f 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000003a301d3b 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()::operator()() const @ 0x000000003a3019c9 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000003a30131f 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a2c866d 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a29d717 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000003a2c67d4 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e76f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d33c 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:04.184077 [ 46934 ] {cd8928fd-2f2e-4662-9e76-0127a231cb37} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_38_38_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53398) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 31), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:04.197303 [ 43368 ] {afb029c2-2738-43d8-be97-fb40aff21681} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_38_38_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53392) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 31), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:04.209397 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_38_38_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:04.216185 [ 43368 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_38_38_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:04.264018 [ 46929 ] {39183129-bde7-4a5e-a64b-268635d32876} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_38_38_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53406) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r10 SELECT 31), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:04.286467 [ 46929 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_38_38_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:04.310390 [ 45838 ] {f4860274-a935-431e-9526-8e6c47878c08} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_38_38_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53420) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r4 SELECT 31), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:04.315934 [ 47191 ] {35b12e44-8696-4e54-a69f-2a39eaa396cc} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_38_38_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53430) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 31), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:04.336236 [ 45838 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_38_38_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:04.339421 [ 47191 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_38_38_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:04.975979 [ 46927 ] {46439e06-26af-4374-b0bc-c342d14f58c2} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_40_40_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53560) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 31), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:04.993740 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_40_40_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:05.070933 [ 43368 ] {fb16bace-6d2c-459f-9678-056f52e1ee6d} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_40_40_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53568) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 32), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:05.099476 [ 43368 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_40_40_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:05.183173 [ 46929 ] {c489fa7c-1e56-4ed9-adf3-e4bfbc91317c} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_40_40_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r1 r3 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53590) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r8 SELECT 32), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:05.186755 [ 47191 ] {47bc0880-b584-41bb-b9f8-b2322c6da0ba} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_40_40_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r1 r3 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53576) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 32), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:05.203962 [ 46929 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_40_40_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r1 r3 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:05.207376 [ 47191 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_40_40_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r1 r3 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:05.868123 [ 47191 ] {8f76956c-d830-4324-ab70-3a99662be692} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_41_41_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53674) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 33), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:05.890796 [ 47191 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_41_41_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:05.904223 [ 43368 ] {21fabcd2-2ef0-46c9-8d25-10e997d7f71f} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_41_41_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53690) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 33), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:05.929076 [ 46932 ] {cf0fc5ce-7d6d-4f9f-814d-c5c0858cccc0} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_41_41_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53698) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r4 SELECT 33), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:05.930327 [ 43368 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_41_41_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:05.938939 [ 45838 ] {7c6851e4-1915-4ebe-8fe7-158b1e1aed5a} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_41_41_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53704) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 33), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:05.950086 [ 46932 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_41_41_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:05.962172 [ 45838 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_41_41_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:05.976921 [ 46930 ] {1ad10859-59cd-4d8a-972f-b9618fca55da} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_41_41_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53718) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r10 SELECT 33), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:05.994571 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_41_41_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:06.038905 [ 46934 ] {0ec6a26f-7948-4f8d-9536-169c2283bf1f} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_41_41_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53728) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 32), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:06.062494 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_41_41_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:06.860925 [ 46933 ] {805bad11-d42b-408a-b1a9-b34c3582e5c4} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_42_42_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53846) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r8 SELECT 34), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:06.874751 [ 46927 ] {f88aed1a-c822-48f4-a52f-81da890c46d2} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_42_42_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53856) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 34), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:06.884889 [ 46933 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_42_42_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:06.905980 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_42_42_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:06.929316 [ 43368 ] {f393b932-b039-4ab7-982c-843ba803d056} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_42_42_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53860) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 34), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:06.948863 [ 43368 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_42_42_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:06.964269 [ 46929 ] {b342fd38-d0c0-4b90-bbc2-1a463afd3c57} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_42_42_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r7 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53872) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 34), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:06.987276 [ 46929 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_42_42_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r7 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:07.000158 [ 46931 ] {3f8973b7-7b9a-45b0-9c97-5feea7b86cef} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_42_42_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r6 r7 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53882) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 34), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:07.020330 [ 46931 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_42_42_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r6 r7 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:07.029492 [ 46932 ] {920f9b7f-7dbe-42b2-96c6-154817ef687e} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_42_42_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r4 r6 r7 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53896) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r10 SELECT 34), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:07.049293 [ 46932 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_42_42_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r4 r6 r7 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:07.672219 [ 46934 ] {ee57622c-f9a3-49f0-ba30-547dc1b93ae7} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_43_43_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54012) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r4 SELECT 35), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:07.683432 [ 47191 ] {759cf122-a0e8-4ee4-b934-170a613f341b} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_43_43_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54026) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 34), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:07.692829 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_43_43_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:07.706822 [ 47191 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_43_43_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:07.951123 [ 46927 ] {5b339095-6ee9-44ac-9b56-9994cce0243c} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_43_43_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r10 r7 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54038) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 35), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:07.962135 [ 46933 ] {d67c57ff-0b37-4f4a-9344-6a37685ce668} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_43_43_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r10 r7 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54036) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r8 SELECT 35), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:07.967972 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_43_43_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r10 r7 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:07.980857 [ 46933 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_43_43_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r10 r7 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:08.001462 [ 43368 ] {61a04810-a105-4da9-9e49-e68229cb0b5d} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_43_43_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r10 r4 r7 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54052) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 35), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:08.022068 [ 43368 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_43_43_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r10 r4 r7 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:08.593326 [ 46929 ] {5d8ed833-6462-4de4-b96c-4057ba39ec11} executeQuery: Code: 286. DB::Exception: Another quorum insert has been already started. (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54116) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 36), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1105: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000003a30a17f 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000003a301d3b 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()::operator()() const @ 0x000000003a3019c9 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000003a30131f 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a2c866d 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a29d717 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000003a2c67d4 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e76f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d33c 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 09:17:08.619002 [ 46929 ] {} TCPHandler: Code: 286. DB::Exception: Another quorum insert has been already started. (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1105: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000003a30a17f 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000003a301d3b 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()::operator()() const @ 0x000000003a3019c9 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000003a30131f 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a2c866d 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a29d717 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000003a2c67d4 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e76f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d33c 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:08.630840 [ 46933 ] {ccc7158a-cc39-4306-ac6e-63dc28865b83} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_44_44_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54148) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 36), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:08.656856 [ 46933 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_44_44_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:08.692365 [ 46930 ] {55262b2f-69de-4c53-895f-7a4a08f7ecd3} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_44_44_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54168) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 36), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:08.696554 [ 46934 ] {a7698725-dfcd-41e6-a67c-5ba2b4e7a7f3} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_44_44_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54174) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 35), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:08.700440 [ 45838 ] {a0e87bee-e7c4-49d8-9a86-70b20907f792} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_44_44_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54162) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r10 SELECT 36), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:08.712378 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_44_44_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:08.714110 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_44_44_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:08.723733 [ 45838 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_44_44_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:08.838818 [ 47191 ] {f9b46b08-3d16-4c4f-9cca-64bbf35bb3b4} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_44_44_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r6 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54184) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r4 SELECT 36), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:08.860157 [ 47191 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_44_44_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r6 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:09.602295 [ 45838 ] {1ff2b30b-d97e-42b8-a28c-8f762864dfb7} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_46_46_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54262) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 37), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:09.620283 [ 46930 ] {76ac02c4-fbcd-4cac-bb4a-0dacd0ded4f8} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_46_46_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54266) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r8 SELECT 37), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:09.623625 [ 45838 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_46_46_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:09.637037 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_46_46_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:09.644632 [ 46934 ] {7b3b4cf5-0d4f-4818-ba7c-5ab7412a4318} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_46_46_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54274) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 37), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:09.665233 [ 47191 ] {9b6d63f9-d100-4b7c-8588-e73bcbebbcb2} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_46_46_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54284) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 37), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:09.667221 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_46_46_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:09.687992 [ 47191 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_46_46_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:09.693112 [ 46927 ] {f84f4ef5-766b-465b-b162-873d8f02a842} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_46_46_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r2 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54296) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 37), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:09.729507 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_46_46_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r2 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:09.761403 [ 43368 ] {edd3dc46-1bd6-4267-93f9-aab806fdb409} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_46_46_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r2 r4 r5 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54312) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 36), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:09.789324 [ 43368 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_46_46_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r2 r4 r5 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:10.372939 [ 46929 ] {22e47767-a1ed-48d3-b861-c949c825721c} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_47_47_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54418) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 38), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:10.392129 [ 46933 ] {0652a320-a08e-421d-badf-ed7983871251} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_47_47_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54428) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r10 SELECT 38), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:10.396219 [ 46929 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_47_47_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:10.398138 [ 46931 ] {43761a1a-35c9-4c18-8ce2-5ef4dc43d102} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_47_47_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54440) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r4 SELECT 38), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:10.416690 [ 46931 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_47_47_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:10.419752 [ 46933 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_47_47_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:10.602666 [ 46932 ] {d423ff4d-c537-484f-9ffc-bae97ee230ab} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_47_47_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r7 r8 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54452) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 38), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:10.621205 [ 46932 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_47_47_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r7 r8 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:11.303973 [ 45838 ] {9ab40cad-3bc4-495e-9eb1-c32846332492} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_48_48_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54586) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 39), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:11.305936 [ 46930 ] {69c898b0-f211-4317-84bf-ccdbe5306aec} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_48_48_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54592) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r8 SELECT 39), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:11.309409 [ 46932 ] {ee36e1f2-cbe9-47d8-92d1-e74b0e69c9fa} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_48_48_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54572) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 39), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:11.320427 [ 47191 ] {37365eed-ec33-470a-b594-031b7ee1533e} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_48_48_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54604) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 39), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:11.322685 [ 45838 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_48_48_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:11.330202 [ 46932 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_48_48_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:11.331557 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_48_48_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:11.332083 [ 46934 ] {90c051b7-ec30-48bc-890a-9934b21cef55} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_48_48_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54598) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 38), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:11.355538 [ 47191 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_48_48_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:11.365760 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_48_48_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:11.409556 [ 46927 ] {3aefd151-8966-4eb3-b52f-a6e82cbf8e8b} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_48_48_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54612) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r4 SELECT 39), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:11.425068 [ 43368 ] {488c54b5-65a7-4fff-9897-c2de9ba65cb4} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_48_48_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54622) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 39), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:11.433551 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_48_48_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:11.442332 [ 43368 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_48_48_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:11.503560 [ 46933 ] {3a94d90f-b0a0-4c3e-b15f-ecc44f8d9210} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_48_48_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r1 r3 r7 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54632) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r10 SELECT 39), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:11.528475 [ 46933 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_48_48_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r1 r3 r7 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:12.208658 [ 46933 ] {5eddcf54-a4f7-426b-8574-7de5bac6b1b5} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_49_49_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54720) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 40), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:12.234033 [ 46933 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_49_49_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:12.379355 [ 46931 ] {d2cd512d-4cd7-4bcc-bfff-9f39ca6073fb} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_49_49_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r1 r2 r4 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54736) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r8 SELECT 40), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:12.385134 [ 45838 ] {ef0651a2-cd47-4dee-97fb-a50d9e60112b} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_49_49_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r1 r2 r4 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54744) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 40), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:12.387727 [ 46930 ] {93bf5a1f-87d9-4423-862c-9f8e25fc662a} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_49_49_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r1 r2 r4 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54760) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 40), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:12.402010 [ 46931 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_49_49_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r1 r2 r4 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:12.406371 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_49_49_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r1 r2 r4 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:12.406495 [ 45838 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_49_49_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r1 r2 r4 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:12.978246 [ 46927 ] {731092fc-0be9-4cc2-8df7-f1b8776aaff8} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_50_50_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54858) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 41), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:12.999437 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_50_50_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:13.038798 [ 43368 ] {ebe3f18f-0e39-4b4c-91fa-dde722b5272f} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_50_50_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54872) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 40), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:13.058872 [ 43368 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_50_50_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:13.064362 [ 46929 ] {8541d1ef-50ed-4aa1-9d97-544a34487fcd} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_50_50_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54884) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 41), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:13.067144 [ 46931 ] {4257cd62-e171-4348-9466-94fd78175d0f} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_50_50_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54890) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r10 SELECT 41), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:13.083053 [ 46933 ] {eeb80a6e-d52c-431d-b638-89048c16be9d} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_50_50_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54886) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r4 SELECT 41), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:13.083782 [ 46929 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_50_50_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:13.086703 [ 46931 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_50_50_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:13.108574 [ 46933 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_50_50_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:13.966888 [ 45838 ] {0d53c44e-9213-48eb-995a-a0151d18be54} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_51_51_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47220) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 42), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:13.984761 [ 46930 ] {c18a0aea-015b-4ba9-a6b2-a685a4cae39c} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_51_51_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47230) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r8 SELECT 42), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:13.994553 [ 45838 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_51_51_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:14.008984 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_51_51_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:14.044179 [ 46934 ] {60f17b73-fa27-468e-9e2c-c2e59b41d3fe} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_51_51_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r2 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47234) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 42), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:14.052477 [ 47191 ] {f7a1702d-35cb-4655-8941-0d3e0becff8a} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_51_51_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r2 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47238) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 42), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:14.052564 [ 46927 ] {7818377c-b341-4790-b635-ede0fe0cbfff} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_51_51_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r2 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47250) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 42), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:14.065376 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_51_51_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r2 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:14.077210 [ 47191 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_51_51_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r2 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:14.089941 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_51_51_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r2 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:14.102293 [ 43368 ] {5395f499-a2a7-4be3-855a-552a653ac562} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_51_51_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r2 r5 r7 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47266) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 41), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:14.119473 [ 43368 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_51_51_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r2 r5 r7 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:14.761007 [ 47191 ] {7dd483fa-03bd-4a02-9792-6962a27558fc} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_52_52_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47386) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 43), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:14.761565 [ 46934 ] {bd12be03-6c91-4d3e-85b4-2683dcc476ef} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_52_52_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47370) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r4 SELECT 43), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:14.778349 [ 47191 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_52_52_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:14.784041 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_52_52_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:15.606058 [ 46929 ] {ec34f462-2580-4ef4-9b8e-21c4217f72f3} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_53_53_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47494) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 44), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:15.624079 [ 46929 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_53_53_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:15.640658 [ 46933 ] {45f99535-e401-42a9-85bb-a134e0453bf2} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_53_53_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47510) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r8 SELECT 44), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:15.661398 [ 46933 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_53_53_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:15.674700 [ 46932 ] {e58f83a0-087f-48d9-8ed1-f3cd2a45c46c} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_53_53_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47522) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 44), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:15.681554 [ 46931 ] {f4fbfd37-9939-45bf-ad9d-ce9b2e50f9cf} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_53_53_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47524) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 44), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:15.699011 [ 46932 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_53_53_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:15.700496 [ 46931 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_53_53_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:15.737240 [ 45838 ] {a659a9de-7a26-4cca-b94f-6a1fe5196e39} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_53_53_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r10 r3 r6 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47530) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 44), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:15.754935 [ 45838 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_53_53_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r10 r3 r6 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:15.787259 [ 46930 ] {98954570-1173-4c92-83ff-48421643782e} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_53_53_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r10 r3 r5 r6 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47542) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 43), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:15.805703 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_53_53_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r10 r3 r5 r6 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:16.652175 [ 43368 ] {421d7b4e-7bec-43f8-b8f8-adf8e07df0cf} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_54_54_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47668) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 45), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:16.671011 [ 46929 ] {bc9db108-8937-4cd7-8438-76d61a4cbc93} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_54_54_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47676) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r8 SELECT 45), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:16.675169 [ 43368 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_54_54_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:16.695760 [ 46929 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_54_54_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:16.705030 [ 46933 ] {9d750b18-8d8d-4079-9e5a-1d7155641eda} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_54_54_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47684) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 45), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:16.729330 [ 46933 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_54_54_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:16.774395 [ 46934 ] {fd5e4431-b416-447d-b131-c4d6c61e7a7a} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_54_54_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47698) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 45), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:16.799648 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_54_54_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:17.492689 [ 46930 ] {b612b365-f54f-463b-b9ef-cacb59205163} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_55_55_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47806) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 46), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:17.511489 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_55_55_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:17.710637 [ 46927 ] {c784e896-ffe1-4a3c-a595-c381d4631f77} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_55_55_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r1 r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47814) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 46), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:17.730553 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_55_55_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r1 r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:17.756153 [ 43368 ] {fd4951d0-8297-4974-af74-daeb8fee4da3} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_55_55_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r1 r10 r4 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47816) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r8 SELECT 46), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:17.780535 [ 43368 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_55_55_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r1 r10 r4 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:18.367291 [ 46931 ] {ca0761ba-28d7-4289-941b-7f4b7ec7201b} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_56_56_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47922) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 47), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:18.371249 [ 45838 ] {a7a31c07-3d00-444c-89cf-cf7327323329} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_56_56_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47924) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 46), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:18.376135 [ 46934 ] {779740a4-2512-41ad-b7cd-f426d5384064} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_56_56_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47932) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 47), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:18.385503 [ 45838 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_56_56_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:18.386969 [ 46931 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_56_56_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:18.397843 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_56_56_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:18.420088 [ 46927 ] {1b125f63-1983-4f26-ba32-2229029190a6} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_56_56_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47944) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 47), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:18.441504 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_56_56_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:18.558716 [ 47191 ] {17381083-9663-41bc-bed4-e530aac43686} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_56_56_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47946) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 47), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:18.582583 [ 47191 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_56_56_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:19.286836 [ 47191 ] {e0c0fc75-13f0-4eef-a2a2-af24f2523b43} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_57_57_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48022) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 48), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:19.311879 [ 47191 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_57_57_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:19.348766 [ 46929 ] {fb18d1bf-8882-4bb3-9645-b02528971637} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_57_57_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48030) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r8 SELECT 48), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:19.369738 [ 46929 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_57_57_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:19.446727 [ 43368 ] {ce2be838-4668-4fe3-8918-bf2927e4bb2f} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_57_57_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r2 r7 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48042) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 48), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:19.469771 [ 43368 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_57_57_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r2 r7 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:20.011815 [ 46931 ] {c76a020b-6252-42ab-ae32-b189ec151d70} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_58_58_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48126) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r4 SELECT 49), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:20.031279 [ 46931 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_58_58_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:20.081472 [ 46934 ] {d0035211-e0d2-4964-8923-f0092ab05535} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_58_58_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48140) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 49), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:20.083378 [ 46930 ] {6c9bed53-66fc-4598-afa1-fdf6937bbd16} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_58_58_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48148) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 48), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:20.085600 [ 46927 ] {1c0fdd2a-303b-48b8-b332-bd3ee48d0320} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_58_58_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48146) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 49), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:20.109227 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_58_58_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:20.110529 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_58_58_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:20.111308 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_58_58_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:20.194332 [ 2135 ] {a8daeb8c-742b-4328-97dc-a82f01d1edc4} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_58_58_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48158) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 49), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:20.231982 [ 2135 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_58_58_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:20.901957 [ 46927 ] {47117270-6326-4ad9-96fe-f506e22d6151} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_59_59_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48272) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 50), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:20.908143 [ 46930 ] {394d3b89-3407-4761-96eb-359a66dfd5fa} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_59_59_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48286) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r8 SELECT 50), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:20.922582 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_59_59_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:20.928766 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_59_59_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:21.725569 [ 46930 ] {2466cedc-8dbd-4518-9c96-64c6dc217050} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_60_60_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48386) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r4 SELECT 51), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:21.749227 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_60_60_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:21.776285 [ 46932 ] {f9de3e57-73c2-4758-af99-51eb565d7c9e} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_60_60_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48396) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 51), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:21.800291 [ 46932 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_60_60_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:21.812670 [ 46931 ] {426c4091-4ece-44c7-905b-bbdc6651255f} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_60_60_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48408) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 51), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:21.835365 [ 46938 ] {6111813b-58dd-462e-8762-9895e28c2c28} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_60_60_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48410) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 50), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:21.852842 [ 46931 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_60_60_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:21.873695 [ 46938 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_60_60_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:21.890806 [ 46939 ] {6ece1caa-b9ea-4a1b-9293-07c9875ba472} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_60_60_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48416) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 51), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:21.913640 [ 46939 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_60_60_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:22.532558 [ 46939 ] {de37387a-8761-49d3-9970-6aa9fe929e5e} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_62_62_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48498) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 52), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:22.543065 [ 46930 ] {ec6354d6-8141-4d1c-8ca8-c6ae36196f7f} executeQuery: Code: 286. DB::Exception: Another quorum insert has been already started. (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48482) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r7 SELECT 52), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1105: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000003a30a17f 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000003a301d3b 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()::operator()() const @ 0x000000003a3019c9 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000003a30131f 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a2c866d 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a29d717 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000003a2c67d4 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e76f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d33c 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 09:17:22.555053 [ 46939 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_62_62_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:22.573087 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Another quorum insert has been already started. (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1105: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000003a30a17f 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000003a301d3b 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()::operator()() const @ 0x000000003a3019c9 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000003a30131f 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a2c866d 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a29d717 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000003a2c67d4 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e76f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d33c 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:22.633175 [ 46934 ] {396743d9-24a8-4ebd-bde8-285b19603f23} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_62_62_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48504) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r8 SELECT 52), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:22.641003 [ 46927 ] {35380440-2ca6-4549-97ab-bf0a3daff0ba} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_62_62_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48514) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 52), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:22.654256 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_62_62_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:22.657134 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_62_62_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:22.810507 [ 46932 ] {85eda520-90df-452e-b126-354fc5448c2f} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_62_62_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r10 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48522) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 52), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:22.832191 [ 46931 ] {5647f3c9-eeaa-4e86-b90e-259d26cbdad0} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_62_62_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r10 r8 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48534) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r4 SELECT 52), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:22.843346 [ 46930 ] {729d2465-bb9f-4b77-95bc-1cdd70848d7a} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_62_62_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r10 r8 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48532) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 52), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:22.844835 [ 46932 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_62_62_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r10 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:22.853174 [ 46931 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_62_62_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r10 r8 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:22.860459 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_62_62_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r10 r8 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:22.884917 [ 46938 ] {abf15c61-b9b3-4e70-a901-53e02662fde3} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_62_62_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r10 r6 r8 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48544) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 51), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:22.905039 [ 46938 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_62_62_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r10 r6 r8 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:23.510741 [ 46930 ] {73ce65f4-2755-49df-9c75-427f5a38d2bf} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_63_63_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38956) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 53), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:23.534502 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_63_63_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:23.573918 [ 46932 ] {7a85f0e4-38a1-4fc5-a264-1e17bc45b0a9} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_63_63_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38970) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 53), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:23.581170 [ 46940 ] {a4b42f68-4b76-4c38-87fd-188f9a25aa8d} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_63_63_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38976) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r7 SELECT 53), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:23.599200 [ 46932 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_63_63_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:23.630788 [ 46940 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_63_63_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:23.679309 [ 46941 ] {decd666d-4f4b-4cb8-ac35-5fe5886a7851} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_63_63_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r10 r4 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38990) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r8 SELECT 53), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:23.699696 [ 46941 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_63_63_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r10 r4 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:24.274822 [ 46930 ] {c8ead5a3-7a91-435a-a362-15afdd74da98} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_64_64_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39088) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 54), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:24.308484 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_64_64_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:24.412333 [ 46940 ] {4d3b9fd1-77ad-4857-8fd7-e4fff6623120} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_64_64_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39098) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r4 SELECT 54), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:24.413576 [ 46941 ] {7ed94892-a141-4c8f-8f5b-5961ec7ce4ed} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_64_64_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39102) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 54), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:24.431724 [ 46941 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_64_64_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:24.434384 [ 46940 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_64_64_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:24.435204 [ 45838 ] {083ac1d1-d15e-47ed-8a41-f12cbd0ac836} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_64_64_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39116) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 54), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:24.442131 [ 46935 ] {78adb5e7-e1b5-4470-a3ba-a0d84e07ac16} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_64_64_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39124) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 53), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:24.460021 [ 45838 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_64_64_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:24.468149 [ 46935 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_64_64_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:24.614391 [ 46930 ] {bfcf1fe0-1605-4945-ba91-82fbdce3ebcd} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_64_64_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r1 r10 r3 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39138) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 54), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:24.638125 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_64_64_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r1 r10 r3 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:25.275293 [ 46930 ] {e984b8d6-a81d-4e30-9ceb-cb11697d04ed} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_65_65_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39236) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r7 SELECT 55), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:25.282761 [ 46932 ] {238b8a25-ed38-4c22-9a2c-58bc9d93c6ce} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_65_65_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39252) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r8 SELECT 55), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:25.289931 [ 46933 ] {1bf39414-4982-4230-915d-d6240d0b421d} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_65_65_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39268) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 55), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:25.303197 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_65_65_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:25.308706 [ 46932 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_65_65_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:25.315944 [ 46933 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_65_65_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:25.363664 [ 46928 ] {4aef8bee-e53f-4a6c-80ce-8e496e62653e} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_65_65_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39284) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 55), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:25.392620 [ 46928 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_65_65_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:25.409934 [ 46934 ] {602202ee-6c24-4219-8713-c3f0c487ab06} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_65_65_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39288) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r4 SELECT 55), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:25.432188 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_65_65_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:25.437587 [ 46927 ] {45ffb0ba-58b5-4bbf-854c-abe3254afa29} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_65_65_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39300) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 55), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:25.456501 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_65_65_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:25.533637 [ 46931 ] {f8eaf90c-ca8e-455a-aa1c-956d0dd428cc} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_65_65_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r10 r8 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39304) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 54), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:25.553463 [ 46931 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_65_65_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r10 r8 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:26.122532 [ 46934 ] {1b6474c6-73b8-43a5-a0c3-b4831b27ec12} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_66_66_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39396) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 56), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:26.143364 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_66_66_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:26.243632 [ 46928 ] {d0e9acd3-a256-4589-b420-cbea37e224b2} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_66_66_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39400) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 56), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:26.265117 [ 46928 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_66_66_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:27.049457 [ 46927 ] {5e0ddc1c-f649-4694-af42-d7aa41a3f88f} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_67_67_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39532) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r7 SELECT 57), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:27.050525 [ 46939 ] {6b2a9b21-ae8b-4035-ab2e-8e7e8c7a600e} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_67_67_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39540) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r4 SELECT 57), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:27.069491 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_67_67_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:27.075334 [ 46939 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_67_67_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:27.104195 [ 46932 ] {b077bcbb-f22d-4027-9bc5-5208556dcec0} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_67_67_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39552) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 57), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:27.125988 [ 46932 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_67_67_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:27.183950 [ 46940 ] {2bcf29c3-229f-486f-a58b-48f6cf502ad0} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_67_67_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39566) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 56), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:27.185697 [ 46941 ] {1c1a27b1-a1d9-4310-ab04-387b5d0a1634} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_67_67_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39582) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 57), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:27.206522 [ 46941 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_67_67_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:27.208726 [ 46940 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_67_67_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r10 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:27.802594 [ 46927 ] {d732a3f7-5693-4f80-8d62-0c200f78b852} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_68_68_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r6 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39658) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 58), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:27.816797 [ 46938 ] {81816d94-7048-4867-bcc4-3fec8342dc68} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_68_68_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r6 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39666) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r10 SELECT 58), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:27.826406 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_68_68_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r6 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:27.841367 [ 46938 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_68_68_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r6 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:28.108645 [ 46932 ] {bec646c4-6962-407e-a638-a9d498e7c8ec} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_68_68_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r2 r4 r6 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39682) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 58), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:28.132801 [ 46932 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_68_68_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r2 r4 r6 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:28.768571 [ 46928 ] {5dc9d280-0f64-4988-b68e-53905adbdfd0} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_69_69_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r6 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39792) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r7 SELECT 59), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:28.782746 [ 46927 ] {59acc8fc-898f-4030-8073-171a126a0335} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_69_69_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r6 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39808) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 59), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:28.799537 [ 46933 ] {7bb7c059-6969-4688-9d6c-70ea5e633791} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_69_69_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r6 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39780) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 59), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:28.804560 [ 46928 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_69_69_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r6 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:28.805626 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_69_69_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r6 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:28.815433 [ 46934 ] {f9650095-9817-42eb-b8a3-508a5400454e} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_69_69_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r6 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39802) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r4 SELECT 59), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:28.827987 [ 46933 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_69_69_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r6 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:28.844683 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_69_69_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r6 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:28.875563 [ 46938 ] {bddefe11-3066-4bb8-9d44-ecad4c0b6f80} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_69_69_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r6 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39814) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r10 SELECT 59), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:28.899196 [ 46938 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_69_69_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r6 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:28.904321 [ 46939 ] {91873d27-454f-4185-a1d6-039dcbcc54c9} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_69_69_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r6 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39826) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 59), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:28.924523 [ 46939 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_69_69_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r6 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:28.950961 [ 46930 ] {49fd2f91-2bf5-4eb8-9019-d7ba1d289ce4} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_69_69_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r10 r6 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39836) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 58), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:28.985179 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_69_69_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r10 r6 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:29.737560 [ 46930 ] {a8878ca6-fdd4-47ae-a2a5-63e95cfa1611} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_70_70_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39924) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 60), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:29.759718 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_70_70_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:30.493997 [ 46933 ] {c109066e-ba1a-416b-bd2f-b646e24a4f2b} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_71_71_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r6 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40034) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 61), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:30.497439 [ 46928 ] {c05427d3-5edf-4e8c-8c8e-d13f77ff7c0c} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_71_71_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r6 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40050) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r7 SELECT 61), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:30.518650 [ 46928 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_71_71_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r6 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:30.519354 [ 46933 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_71_71_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r6 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:30.556721 [ 46934 ] {d0e04879-c5a2-468a-a93b-4a57dd1342cc} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_71_71_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r6 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40066) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 61), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:30.570026 [ 46927 ] {3794311d-868e-465b-bad9-c95aadd0ecbe} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_71_71_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r6 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40074) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 61), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:30.588242 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_71_71_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r6 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:30.600083 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_71_71_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r6 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:30.619678 [ 46932 ] {a413f42e-3c78-4755-8d83-c19a2fc6a25a} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_71_71_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r6 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40080) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r10 SELECT 61), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:30.640125 [ 46932 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_71_71_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r6 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:30.644154 [ 46938 ] {1f9804e3-4006-4b7b-92e5-6aa9063699ae} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_71_71_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r6 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40092) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 60), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:30.678259 [ 46938 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_71_71_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r6 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:31.407195 [ 46935 ] {93ee894f-e1c5-4e1f-b03b-943fa52276d7} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_72_72_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r6 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40184) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 62), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:31.427249 [ 46935 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_72_72_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r6 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:31.573092 [ 46930 ] {afeda3af-8459-42c9-82ea-59f2fd30942f} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_72_72_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r6 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40192) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 62), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:31.593854 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_72_72_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r6 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:31.594369 [ 46928 ] {32ef8f7d-4d5c-4054-a5a1-a21e0f090a29} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_72_72_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r10 r6 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40196) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r7 SELECT 62), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:31.603888 [ 46934 ] {7edc0c1d-0a03-4ecc-8223-2d26f883eea4} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_72_72_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r1 r10 r6 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40202) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 62), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:31.612238 [ 46928 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_72_72_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r10 r6 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:31.622493 [ 46932 ] {fff8490f-cff3-42fe-ac14-b483a3f8f0d3} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_72_72_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r1 r10 r6 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40200) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 62), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:31.626748 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_72_72_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r1 r10 r6 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:31.642399 [ 46932 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_72_72_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r1 r10 r6 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:32.223891 [ 46939 ] {31c0325f-cec8-497d-931e-66de79b43790} executeQuery: Code: 286. DB::Exception: Another quorum insert has been already started. (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40278) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 63), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1105: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000003a30a17f 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000003a301d3b 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()::operator()() const @ 0x000000003a3019c9 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000003a30131f 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a2c866d 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a29d717 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000003a2c67d4 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e76f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d33c 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 09:17:32.257674 [ 46939 ] {} TCPHandler: Code: 286. DB::Exception: Another quorum insert has been already started. (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1105: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000003a30a17f 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000003a301d3b 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()::operator()() const @ 0x000000003a3019c9 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000003a30131f 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a2c866d 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a29d717 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000003a2c67d4 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e76f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d33c 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:32.288486 [ 46930 ] {a86df88d-c328-49c3-9be0-6cbf0334d026} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_73_73_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40292) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r10 SELECT 63), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:32.314231 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_73_73_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:32.324407 [ 46940 ] {cc4329ff-e47b-4f64-b926-8320bbe1a9b1} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_73_73_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40294) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 62), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:32.344039 [ 46940 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_73_73_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:32.417895 [ 46935 ] {56776811-c6a5-4e65-b437-c435087996ae} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_73_73_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40310) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 63), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:32.441993 [ 46935 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_73_73_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:33.188966 [ 46930 ] {834256cd-96ec-4974-b0d9-028202548ea6} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_75_75_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35832) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 64), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:33.196458 [ 46935 ] {dcbaefd7-5e15-4894-9c40-4b611de01717} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_75_75_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35838) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 64), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:33.210243 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_75_75_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:33.214263 [ 46928 ] {124e6795-a167-4408-a09a-c26ecc259003} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_75_75_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35842) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 64), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:33.217975 [ 46935 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_75_75_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:33.246696 [ 46928 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_75_75_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:33.291985 [ 46932 ] {f6be9c96-ffe9-4f1d-9ca1-f0437b479861} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_75_75_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r3 r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35852) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r7 SELECT 64), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:33.311954 [ 46932 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_75_75_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r3 r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:33.321770 [ 46934 ] {8ab8879d-41c8-4fd7-b738-ad9024e8e6b5} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_75_75_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r3 r4 r5 r6 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35866) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 64), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:33.329292 [ 46927 ] {ca62e645-4bf9-4fc5-80bf-66d39fc41410} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_75_75_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r3 r4 r5 r6 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35868) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r10 SELECT 64), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:33.340670 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_75_75_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r3 r4 r5 r6 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:33.347997 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_75_75_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r3 r4 r5 r6 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:33.897993 [ 46927 ] {f5dde8c4-d768-4403-b959-eac0c2c983cd} executeQuery: Code: 286. DB::Exception: Another quorum insert has been already started. (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35954) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r4 SELECT 65), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1105: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000003a30a17f 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000003a301d3b 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()::operator()() const @ 0x000000003a3019c9 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000003a30131f 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a2c866d 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a29d717 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000003a2c67d4 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e76f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d33c 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 09:17:33.930877 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Another quorum insert has been already started. (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1105: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000003a30a17f 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000003a301d3b 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()::operator()() const @ 0x000000003a3019c9 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000003a30131f 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a2c866d 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a29d717 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000003a2c67d4 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e76f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d33c 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:33.951805 [ 46938 ] {95ac858b-4d2c-4813-9e5f-d96193a86c48} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_76_76_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35968) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 64), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:33.972596 [ 46939 ] {a99b82b5-4cb5-44ad-9aea-bb501f728f9d} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_76_76_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35984) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 65), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:33.975705 [ 46938 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_76_76_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:33.989101 [ 46939 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_76_76_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:34.876300 [ 46933 ] {b8b1f6f1-b36b-47db-8129-1f40240a9e4a} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_78_78_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36088) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 66), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:34.876385 [ 46940 ] {aaa6dbf5-4c20-4927-91d1-48995d4d9c95} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_78_78_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36084) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 66), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:34.892973 [ 46933 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_78_78_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:34.897677 [ 46930 ] {d491e75e-490a-4d49-9504-a7b13b8fa0e8} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_78_78_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36098) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 66), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:34.907507 [ 46940 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_78_78_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:34.916068 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_78_78_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:34.999360 [ 46935 ] {d8b0f46e-2e8e-4c54-ab1b-5699048c17ce} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_78_78_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36114) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r10 SELECT 66), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:35.002380 [ 46928 ] {d7a832f0-c932-4362-b9a5-1a7c059aca49} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_78_78_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36120) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 66), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:35.027336 [ 46935 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_78_78_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:35.034948 [ 46928 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_78_78_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:35.044687 [ 46934 ] {b8fef48e-0489-4c8b-9bc4-aef54eaf92db} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_78_78_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r7 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36136) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r4 SELECT 66), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:35.056040 [ 46927 ] {917c1c63-c217-4f99-88d2-e6c7fea9c9da} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_78_78_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r10 r7 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36144) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r7 SELECT 66), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:35.066638 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_78_78_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r7 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:35.082497 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_78_78_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r10 r7 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:35.686396 [ 46939 ] {923e3b3b-83c4-4eb0-ae23-873c95b3afdc} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_79_79_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36240) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 66), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:35.690694 [ 46940 ] {ede2e32c-3e10-4965-91f6-6a92bed267ba} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_79_79_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36238) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 67), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:35.707217 [ 46939 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_79_79_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:35.740270 [ 46940 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_79_79_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:36.516469 [ 46930 ] {0cd62c97-1fe4-4f48-8342-0af087657641} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_80_80_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36362) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 68), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:36.525571 [ 46935 ] {ede66142-608b-40d3-af99-4c9a06c30bd5} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_80_80_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36364) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 68), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:36.536924 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_80_80_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:36.546141 [ 46935 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_80_80_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:36.579628 [ 46928 ] {4c64dd18-58a7-4c5f-b276-69d17aa31b16} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_80_80_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36376) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 68), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:36.583557 [ 46934 ] {5d263402-76fa-4e14-9441-3f3d9520e3c4} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_80_80_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36380) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 68), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:36.583620 [ 46927 ] {242d58f4-eed9-42f4-a6b8-2c362f9ab11b} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_80_80_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36392) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r10 SELECT 68), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:36.596467 [ 46928 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_80_80_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:36.604950 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_80_80_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:36.606561 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_80_80_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:36.684994 [ 46938 ] {abaec2f2-80b2-4c5f-8f28-38bd76ba93cd} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_80_80_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r1 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36408) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r4 SELECT 68), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:36.692343 [ 46932 ] {e3067bab-28d5-4025-9b61-e356deb91b9b} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_80_80_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r1 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36422) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r7 SELECT 68), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:36.702206 [ 46938 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_80_80_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r1 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:36.712454 [ 46932 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_80_80_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r1 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:37.603257 [ 46928 ] {1ef892d2-2bbc-4137-8788-97bbe4d146ba} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_81_81_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36530) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 69), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:37.617389 [ 46927 ] {4727bb4a-77c0-4dc6-9188-e86d8683abb5} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_81_81_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36536) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 68), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:37.626546 [ 46928 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_81_81_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:37.637408 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_81_81_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:37.642654 [ 46932 ] {c13d897c-3402-4a75-9024-e2bf7a35661b} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_81_81_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36548) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 69), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:37.668991 [ 46932 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_81_81_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:37.675752 [ 46938 ] {42552ba9-b764-4dcf-a0df-906b88a32d4a} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_81_81_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36542) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 69), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:37.677724 [ 46940 ] {196f960d-621d-4614-b713-41cd9d6482a8} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_81_81_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36560) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 69), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:37.690993 [ 46939 ] {22418b7f-c6d8-42d4-a3f4-9ba4c4065459} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_81_81_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36572) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r10 SELECT 69), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:37.698025 [ 46938 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_81_81_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:37.698106 [ 46940 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_81_81_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:37.712260 [ 46939 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_81_81_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:37.730244 [ 46933 ] {6573dae0-fc22-4d99-94fe-780fe6050cb6} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_81_81_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36580) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 69), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:37.757015 [ 46934 ] {344de142-436a-4630-9a7c-8dcc25996236} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_81_81_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36602) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r4 SELECT 69), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:37.758784 [ 46933 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_81_81_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:37.780710 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_81_81_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:37.788288 [ 46930 ] {dc56bbbf-ad98-4fa6-bc00-d9f32fe0be6d} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_81_81_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r10 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36590) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r7 SELECT 69), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:37.818751 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_81_81_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r10 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:38.668405 [ 46938 ] {81100278-829e-43e9-af51-569c56c3f33f} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_82_82_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r2 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36704) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 70), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:38.676491 [ 46927 ] {544e3b5c-364b-448f-b4f6-269108d38d84} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_82_82_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r2 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36702) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 69), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:38.695075 [ 46938 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_82_82_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r2 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:38.704495 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_82_82_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r2 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:38.747676 [ 46932 ] {d7700dc3-b43e-438c-98ae-533e0b31b6bc} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_82_82_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r10 r2 r4 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36714) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r10 SELECT 70), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:38.765686 [ 46932 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_82_82_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r10 r2 r4 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:39.402745 [ 46939 ] {01f64844-f54c-4303-92ec-2479e30c9ff5} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_83_83_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36794) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 71), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:39.418434 [ 46933 ] {404e9bad-9d4b-40b4-b4f0-96438d83bee8} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_83_83_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36810) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 71), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:39.419456 [ 46939 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_83_83_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:39.428879 [ 46930 ] {76b6bf1c-a712-4058-a5f0-cff361b488e3} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_83_83_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36822) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 71), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:39.429329 [ 46935 ] {cdb014a3-6793-4e8b-b652-61bed9c7a82b} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_83_83_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36824) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r4 SELECT 71), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:39.442758 [ 46933 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_83_83_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:39.448924 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_83_83_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:39.452509 [ 46935 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_83_83_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:39.459738 [ 46928 ] {fb1c27e8-4e92-4be9-9b34-b3837029ba2b} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_83_83_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36836) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r7 SELECT 71), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:39.468630 [ 46934 ] {c896a3db-3a52-49cc-9d6a-d938429a594c} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_83_83_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36840) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 71), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:39.480229 [ 46928 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_83_83_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:39.485476 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_83_83_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:40.306221 [ 46938 ] {03701d4a-488e-4958-938e-79a5410b3f3e} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_84_84_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36958) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 72), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:40.310352 [ 46932 ] {b6957eb2-dc36-43cd-b34c-8989d338b9b0} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_84_84_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36974) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 71), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:40.327268 [ 46938 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_84_84_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:40.340686 [ 46940 ] {c1c30364-d5e5-4b5a-8535-b298099a8610} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_84_84_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36990) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r10 SELECT 72), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:40.343625 [ 46932 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_84_84_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:40.358204 [ 46940 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_84_84_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:40.443758 [ 46933 ] {07835a3c-e3af-43ed-8ffb-43f5bb6827a2} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_84_84_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r2 r4 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36996) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 72), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:40.461201 [ 46933 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_84_84_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r2 r4 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:41.087217 [ 46934 ] {e21cea87-d7ea-4b22-9a10-a4c6cc216c84} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_85_85_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37094) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 73), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:41.096040 [ 46938 ] {cba3a4c9-ffd6-4ecd-85a9-d275e19e5840} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_85_85_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37106) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 73), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:41.096786 [ 46932 ] {5bf5177e-2e47-4f0e-8c76-10b4109d47de} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_85_85_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37110) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 73), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:41.103574 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_85_85_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:41.118216 [ 46938 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_85_85_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:41.124271 [ 46932 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_85_85_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:41.127120 [ 46940 ] {f8079ae1-9379-4f60-8a37-4451771e8600} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_85_85_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37118) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r7 SELECT 73), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:41.154976 [ 46940 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_85_85_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:41.911696 [ 46930 ] {a07aa05f-8efd-4192-a95d-438b8aa14c17} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_86_86_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37242) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 73), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:41.927218 [ 46934 ] {b78ba180-6665-4b2c-a177-aaaac287a595} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_86_86_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37258) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r10 SELECT 74), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:41.928172 [ 46932 ] {659ee35a-6f04-4a15-8304-4baccc74b21e} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_86_86_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37272) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 74), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:41.934136 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_86_86_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:41.952184 [ 46932 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_86_86_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:41.953472 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_86_86_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:41.993665 [ 46935 ] {464bd1eb-0231-4cd2-8b0a-6c23b022fb77} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_86_86_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37278) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 74), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:42.017073 [ 46935 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_86_86_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:42.726332 [ 46928 ] {34f302cd-1727-4c9b-9a3f-6d138660ab18} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_87_87_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37372) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 75), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:42.739744 [ 46934 ] {bf4a5a73-e42e-4bcd-b577-66e17831a9de} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_87_87_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37374) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 75), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:42.756940 [ 46928 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_87_87_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:42.760147 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_87_87_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:42.785753 [ 46939 ] {bc7a5267-c0c4-420e-a28e-091bb33b279a} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_87_87_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37376) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 75), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:42.796091 [ 46933 ] {7b262224-995f-4e55-aff7-463622926aab} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_87_87_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37378) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r7 SELECT 75), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:42.810764 [ 46939 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_87_87_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:42.819245 [ 46933 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_87_87_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:43.421024 [ 46935 ] {94f4d315-5bc3-45cb-86e8-187b88bee306} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_88_88_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59942) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r8 SELECT 76), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:43.446390 [ 46935 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_88_88_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:43.547711 [ 46939 ] {1b25e537-fbdc-4af3-b485-b822bca68219} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_88_88_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59956) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 76), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:43.556255 [ 46938 ] {310a2099-a2bf-4102-8642-2949e46e7d3a} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_88_88_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59966) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r10 SELECT 76), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:43.559993 [ 46928 ] {35e7fb80-c224-4cd9-8699-7b53545d054c} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_88_88_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59974) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 75), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:43.565994 [ 46939 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_88_88_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:43.578179 [ 46938 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_88_88_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:43.581904 [ 46928 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_88_88_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:43.676133 [ 46940 ] {d0ad64f0-4080-4f12-8721-afec0b5db647} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_88_88_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r4 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59984) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 76), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:43.694969 [ 46940 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_88_88_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r4 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:44.376610 [ 46939 ] {0ca983a0-8bd0-49e9-ab5a-a9e071ec3f05} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_89_89_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60076) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 77), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:44.391436 [ 46938 ] {a563b4c2-10b7-410b-8511-104896c19247} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_89_89_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60068) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 77), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:44.396280 [ 46928 ] {85341087-a559-4809-9d0b-6f5bdd52d209} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_89_89_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60092) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 77), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:44.397820 [ 46939 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_89_89_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:44.413360 [ 46930 ] {305b9ee8-085a-4860-94dc-7de715afb17a} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_89_89_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60090) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r7 SELECT 77), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:44.422875 [ 46938 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_89_89_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:44.424450 [ 46928 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_89_89_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:44.431499 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_89_89_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:44.540896 [ 46927 ] {421b606d-1532-42ab-9730-e1376119ccf3} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_89_89_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r2 r4 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60096) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r8 SELECT 77), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:44.560747 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_89_89_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r2 r4 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:45.196443 [ 46933 ] {b5c6141d-b64f-47c3-926e-b5f2ed1d456b} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_90_90_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60202) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 78), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:45.199401 [ 46939 ] {4f65f7e3-a876-4a98-8c28-31039acf32f2} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_90_90_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60194) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 77), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:45.217501 [ 46928 ] {da9a85c7-05c4-4d1f-bc2c-9470604ec6be} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_90_90_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60204) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r10 SELECT 78), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:45.218474 [ 46939 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_90_90_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:45.226321 [ 46933 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_90_90_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:45.235833 [ 46928 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_90_90_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:45.247151 [ 46927 ] {500d1b9e-caf3-44fa-8417-da51021c508a} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_90_90_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60214) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 78), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:45.284966 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_90_90_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:45.399580 [ 46932 ] {7122b1f0-1d24-40d6-a0bc-dad051ad2b1c} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_90_90_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r1 r4 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60240) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 78), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:45.400141 [ 46930 ] {685491e2-814f-4a9e-9a57-f49335f16e1a} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_90_90_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r1 r4 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60228) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 78), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:45.438974 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_90_90_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r1 r4 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:45.438977 [ 46932 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_90_90_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r1 r4 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:46.029368 [ 46933 ] {527e4419-86a8-4863-8721-e1f5e0153dc4} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_91_91_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60346) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 79), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:46.047805 [ 46935 ] {f30c5e6f-ab86-42aa-88fc-b49cfdc3e8eb} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_91_91_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60358) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r7 SELECT 79), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:46.049641 [ 46933 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_91_91_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:46.070616 [ 46935 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_91_91_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:46.096436 [ 46934 ] {0fe1bd29-8ad2-4d62-8e13-cbf9d847fe5f} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_91_91_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60370) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r8 SELECT 79), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:46.121077 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_91_91_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:46.817863 [ 46933 ] {5fb0331f-9cac-43dc-b08e-17ea6fad19eb} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_92_92_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60476) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 80), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:46.839994 [ 46933 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_92_92_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:46.858292 [ 46935 ] {7f40c6c3-4203-458b-af79-135ecc88ce7a} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_92_92_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60482) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 79), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:46.875464 [ 46934 ] {e701af53-fc0f-4f1c-914f-67843e8e4a95} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_92_92_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60502) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r10 SELECT 80), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:46.886684 [ 46935 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_92_92_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:46.890289 [ 46939 ] {1e82211b-5a4c-4612-92a6-ee2b9dbc1c2c} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_92_92_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60496) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 80), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:46.892398 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_92_92_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:46.919276 [ 46939 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_92_92_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:47.012878 [ 46928 ] {21627e4f-28d1-4813-aaca-e6b4c92688c2} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_92_92_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60514) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 80), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:47.021038 [ 46930 ] {6aa75f3a-a3bf-40e8-bdc6-7a1698a01806} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_92_92_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60522) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 80), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:47.036425 [ 46928 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_92_92_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:47.041677 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_92_92_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:47.103718 [ 46927 ] {bac7c5e3-bfa5-4f2b-9dc5-3ca45dc25f67} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_92_92_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r10 r4 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60538) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r7 SELECT 80), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:47.129440 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_92_92_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r10 r4 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:47.133693 [ 46933 ] {04f5f63f-c26e-4480-814a-075f60a72428} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_92_92_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r10 r3 r4 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60548) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 80), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:47.158019 [ 46933 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_92_92_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r10 r3 r4 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:47.925923 [ 46932 ] {c2853288-c054-42aa-ae4d-8ba1232ea436} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_93_93_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60640) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 80), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:47.945375 [ 46932 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_93_93_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:47.945558 [ 46940 ] {1dc9c4a1-f3fb-4e31-a2be-486335306744} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_93_93_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60642) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r8 SELECT 81), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:47.966597 [ 46928 ] {0336532e-745c-48a8-9c80-4f9242c59dda} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_93_93_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60650) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 80), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:47.971008 [ 46940 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_93_93_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:47.974520 [ 46939 ] {4e9351b6-7fe5-4865-b2ff-eaac140d1ac0} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_93_93_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60660) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 81), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:47.992673 [ 46933 ] {3300e9aa-6a4f-411c-8c54-2507d4a8d08f} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_93_93_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60666) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 81), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:47.993196 [ 46939 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_93_93_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:47.998942 [ 46928 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_93_93_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:48.019164 [ 46933 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_93_93_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:48.022268 [ 46938 ] {b63c01b4-fbc1-4300-8260-3c100b3d6656} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_93_93_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60652) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r10 SELECT 81), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:48.054063 [ 46935 ] {8a5c3b44-b05e-4611-9694-72a3b73d2a32} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_93_93_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60670) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 81), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:48.055480 [ 46938 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_93_93_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:48.080403 [ 46935 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_93_93_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:48.088758 [ 46934 ] {38db8850-d992-4c16-952b-9f2d3f4612f8} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_93_93_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60674) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 81), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:48.106057 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_93_93_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:48.136575 [ 46930 ] {0802281b-c5ee-457d-ba4f-4126e969b657} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_93_93_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60690) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r7 SELECT 81), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:48.155828 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_93_93_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:49.532926 [ 46932 ] {b1bc49ab-cb5a-47a7-ac7e-78f9e9e02934} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_95_95_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60880) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r8 SELECT 83), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:49.553196 [ 46932 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_95_95_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:49.576704 [ 46940 ] {f993cbbe-7c95-4a2b-8248-9ff525d6245b} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_95_95_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60886) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 83), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:49.584969 [ 46928 ] {0a78648f-92e6-473d-8f36-7dd92cd586bf} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_95_95_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60896) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 82), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:49.586348 [ 46938 ] {975aebef-8934-4594-8b60-091c7769165b} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_95_95_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60906) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 82), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:49.593704 [ 46940 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_95_95_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:49.605142 [ 46938 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_95_95_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:49.610144 [ 46928 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_95_95_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:49.612166 [ 46933 ] {f36db637-e448-49f6-b14e-f9a33fabe2ef} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_95_95_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60928) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 83), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:49.621340 [ 46939 ] {33a4ea4b-ad7c-4e50-a927-e1dde9d08af7} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_95_95_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60918) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r10 SELECT 83), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:49.634629 [ 46933 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_95_95_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:49.650207 [ 46939 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_95_95_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:49.688137 [ 46935 ] {04bd0ee4-c756-4dce-8039-32561dd579a2} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_95_95_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60934) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 83), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:49.708209 [ 46935 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_95_95_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:49.731179 [ 46934 ] {733402db-a450-4353-8dcc-9742cc3a411e} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_95_95_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60942) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 83), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:49.762574 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_95_95_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:49.783545 [ 46930 ] {05ba248f-ce55-49f3-a4d5-091cb1bc1abf} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_95_95_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r10 r4 r8 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60954) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r7 SELECT 83), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:49.800551 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_95_95_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r10 r4 r8 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:50.564648 [ 46928 ] {ff3d9543-9904-410b-a95f-edd2c0d81129} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_96_96_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:32816) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r8 SELECT 84), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:50.599467 [ 46928 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_96_96_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:50.650036 [ 46938 ] {6bf5ff82-c6b6-4a20-8291-01cfa97f50da} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_96_96_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r1 r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:32822) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 83), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:50.664917 [ 46939 ] {e456fa8a-0a52-45e7-8c2f-831d17f6c0e0} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_96_96_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r1 r4 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:32824) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 84), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:50.670834 [ 46938 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_96_96_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r1 r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:50.684677 [ 46939 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_96_96_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r1 r4 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:51.227141 [ 46935 ] {f42f56e2-c5bf-4ac7-8b06-74c675e4fbc0} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_97_97_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:32920) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 84), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:51.246328 [ 46935 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_97_97_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:51.256367 [ 46934 ] {7446de87-37e5-4629-99ec-ccdcc1692ab8} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_97_97_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:32934) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 85), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:51.275214 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_97_97_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:51.302250 [ 46930 ] {e7616d67-c0b4-435b-b3c8-daf66ba7cc8c} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_97_97_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:32950) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r10 SELECT 85), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:51.305305 [ 46927 ] {58b11f8f-1b53-4342-a1c5-1529e77b0cb2} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_97_97_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:32964) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 85), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:51.306692 [ 46932 ] {728199db-bc9e-414b-9345-3e803cd4644b} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_97_97_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:32978) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 85), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:51.329974 [ 46932 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_97_97_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:51.331258 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_97_97_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:51.334718 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_97_97_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:51.350601 [ 46940 ] {6945fce2-50e5-4119-92a7-7cd93de3ae62} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_97_97_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:32988) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r7 SELECT 85), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:51.380184 [ 46940 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_97_97_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:52.251416 [ 46927 ] {3f679880-31e4-488b-9a1d-730098b06d27} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_98_98_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33120) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r8 SELECT 86), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:52.263685 [ 46932 ] {40b47abb-291b-4619-a95d-13c547299867} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_98_98_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33124) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 85), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:52.280380 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_98_98_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:52.283446 [ 46932 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_98_98_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:52.317748 [ 46940 ] {bbb3b8ec-6e4f-4313-a2f8-9f482cf694d6} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_98_98_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33128) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 85), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:52.327912 [ 46928 ] {6822effe-9513-4b73-a0b4-02df5409b5ff} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_98_98_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33136) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 86), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:52.336713 [ 46938 ] {09621821-1922-45d3-b520-678f5536b749} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_98_98_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33148) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 86), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:52.339000 [ 46940 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_98_98_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:52.358042 [ 46928 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_98_98_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:52.362973 [ 46938 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_98_98_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:52.398868 [ 46939 ] {4576a3d9-e1b5-4071-b160-06745bbc1f6d} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_98_98_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r10 r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33158) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 86), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:52.400833 [ 46933 ] {c361a516-2c74-4eec-a5d4-d482d26f10a7} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_98_98_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r10 r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33160) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 86), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:52.426238 [ 46933 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_98_98_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r10 r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:52.426697 [ 46939 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_98_98_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r10 r4 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:53.093000 [ 46933 ] {8c1e60bf-b6cf-4356-8a30-45508b37e38e} executeQuery: Code: 286. DB::Exception: Another quorum insert has been already started. (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33264) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r4 SELECT 87), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1105: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000003a30a17f 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000003a301d3b 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()::operator()() const @ 0x000000003a3019c9 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000003a30131f 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a2c866d 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a29d717 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000003a2c67d4 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e76f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d33c 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 2025.06.13 09:17:53.102541 [ 46927 ] {bb461abe-24f7-47da-a293-e47b27f743e9} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_99_99_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33276) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r10 SELECT 87), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:53.123116 [ 46933 ] {} TCPHandler: Code: 286. DB::Exception: Another quorum insert has been already started. (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1105: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000003a30a17f 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000003a301d3b 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()::operator()() const @ 0x000000003a3019c9 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000003a30131f 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a2c866d 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a29d717 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000003a2c67d4 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e76f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d33c 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 21. ? @ 0x00007f5206343ac3 22. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:53.126497 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_99_99_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:53.291367 [ 46934 ] {96b8f71f-499e-416b-a652-436a79f83928} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_99_99_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48726) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 86), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:53.308055 [ 46930 ] {197e5977-2301-446e-a179-61d5b47e48e2} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_99_99_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48732) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r8 SELECT 87), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:53.314593 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_99_99_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:53.327526 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_99_99_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:53.354245 [ 46932 ] {8097c295-c6d5-43d0-9222-8069106463df} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_99_99_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r4 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48736) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 86), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:53.372586 [ 46932 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_99_99_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r4 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:53.993414 [ 46934 ] {4deb7808-4fb1-4264-8bfc-e40f1205ceab} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_101_101_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48830) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 88), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:54.015433 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_101_101_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:54.026253 [ 46938 ] {9276dd62-68a1-488f-a08e-a68251af88c3} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_101_101_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48862) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 88), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:54.042623 [ 46938 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_101_101_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:54.048168 [ 46939 ] {6dba2f21-954b-4d56-8b01-485c82a56010} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_101_101_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48870) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 88), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:54.051311 [ 46928 ] {09d53820-5367-40e9-adce-cdef6d7ec282} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_101_101_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48846) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 88), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:54.072072 [ 46939 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_101_101_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:54.075994 [ 46928 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_101_101_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:54.170103 [ 46933 ] {c17fde40-0eb5-4584-bb6e-67900869e8c4} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_101_101_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r6 r7 r8 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48884) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r4 SELECT 88), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:54.193011 [ 46933 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_101_101_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r6 r7 r8 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:54.770457 [ 46932 ] {eb19d5b1-9438-4317-b670-6faf68adf694} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_102_102_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48964) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r4 SELECT 88), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:54.773397 [ 46934 ] {de517fba-b9b7-4ac1-9af6-a8c5951a2af2} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_102_102_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48966) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r10 SELECT 89), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:54.792155 [ 46932 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_102_102_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:54.792155 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_102_102_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:54.917991 [ 46930 ] {4596c5a4-80c0-4b0c-85aa-850276ed3f3e} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_102_102_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48982) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 88), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:54.937305 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_102_102_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:54.989197 [ 46940 ] {b332d176-e108-445f-9128-e337f1c8d872} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_102_102_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r1 r2 r5 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48988) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r8 SELECT 89), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:55.008106 [ 46940 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_102_102_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r1 r2 r5 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:55.574392 [ 46933 ] {26c1ac50-7f75-49d7-a825-6e0088554aa8} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_103_103_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49098) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 89), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:55.593419 [ 46933 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_103_103_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:55.619292 [ 46935 ] {bf17393d-d8fc-4df2-8f8e-394a9d446079} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_103_103_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49102) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 90), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:55.636694 [ 46935 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_103_103_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:55.639865 [ 46934 ] {a6be7a7c-1c10-4dc7-9fe3-94696f29ee5b} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_103_103_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49120) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 90), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:55.639972 [ 46927 ] {ec8c4e17-2e4d-4c98-a2c2-69b740438fc3} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_103_103_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49114) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 90), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:55.650592 [ 46930 ] {0318e7ca-8457-4371-9949-9c956a23ec0a} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_103_103_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49132) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 90), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:55.663243 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_103_103_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:55.663687 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_103_103_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:55.675167 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_103_103_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:55.831815 [ 46928 ] {63685b5a-2e55-4007-ad26-e0cc5757afad} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_103_103_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r10 r7 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49144) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r4 SELECT 89), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:55.848550 [ 46932 ] {cda1518d-de11-46a4-86dc-7c4122b8bd33} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_103_103_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r10 r7 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49154) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r10 SELECT 90), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:55.854496 [ 46928 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_103_103_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r10 r7 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:55.865642 [ 46932 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_103_103_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r10 r7 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:56.538656 [ 46933 ] {bc80c6c5-9f84-42c3-aff0-06314012ff6f} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_104_104_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49248) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 90), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:56.562533 [ 46933 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_104_104_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:56.674206 [ 46928 ] {54f983a5-3b80-4732-b601-741575454e17} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_104_104_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49254) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 90), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:56.688477 [ 46938 ] {258daf6c-01fb-482a-bbf0-965452270038} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_104_104_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49258) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r8 SELECT 91), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:56.702740 [ 46928 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_104_104_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:56.711851 [ 46938 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_104_104_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:56.719653 [ 46939 ] {fe3d5a67-4f03-4056-bf38-f2c9198b69cc} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_104_104_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49268) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 91), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:56.738412 [ 46939 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_104_104_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:56.747080 [ 46935 ] {08c7d291-e670-4bf4-b077-09ce09c0a610} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_104_104_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r7 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49284) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 91), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:56.757807 [ 46934 ] {076b1d7d-02a2-41bd-8030-ca92c879977b} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_104_104_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r4 r7 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49306) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 91), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:56.770074 [ 46927 ] {30747ac5-e784-4832-a19f-56e6e1355285} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_104_104_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r4 r7 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49300) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 91), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:56.772437 [ 46935 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_104_104_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r7 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:56.784514 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_104_104_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r4 r7 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:56.798558 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_104_104_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r4 r7 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:57.433721 [ 46935 ] {57938fa2-ee81-49b6-9b9d-92ba10e9be6e} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_105_105_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49390) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r4 SELECT 91), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:57.443103 [ 46927 ] {53d271dc-020f-46c9-83cd-ecd70e3f56eb} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_105_105_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49380) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r10 SELECT 92), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:57.454895 [ 46935 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_105_105_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:57.467514 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_105_105_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:58.248747 [ 46934 ] {7f075407-4437-4ff3-b49c-d407212b7c54} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_106_106_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49508) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 92), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:58.257780 [ 46930 ] {45056604-da86-49da-a405-6a6258e5bbd9} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_106_106_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49518) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r8 SELECT 93), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:58.269368 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_106_106_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:58.273775 [ 46928 ] {dd2b4954-a39d-4fb4-8896-db40a4c3f51f} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_106_106_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49530) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 92), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:58.286916 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_106_106_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:58.299898 [ 46928 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_106_106_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:58.336362 [ 46940 ] {b5b7dca3-2faa-4acf-b1a5-86ecb3923e89} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_106_106_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49536) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 93), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:58.337690 [ 46939 ] {f8f18760-4627-40a3-a030-11cb6bf0d3ec} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_106_106_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49558) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 93), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:58.361022 [ 46939 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_106_106_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:58.362626 [ 46940 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_106_106_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:58.378943 [ 46938 ] {3bc1b476-23c1-47c3-ab4d-5e1a94822560} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_106_106_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49552) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 93), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:58.381128 [ 46933 ] {220f7c1b-ea79-41bf-b63b-3d560e3fba5b} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_106_106_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49560) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 93), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:58.417275 [ 46938 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_106_106_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:58.418417 [ 46933 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_106_106_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:59.125763 [ 46932 ] {84fb3f8a-dc7b-47fb-8305-888549b178c1} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_107_107_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49616) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r10 SELECT 94), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:59.144581 [ 46932 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_107_107_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:59.152643 [ 46934 ] {77eb2fe3-7f6e-498f-8d87-64801f6620cd} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_107_107_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49632) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r4 SELECT 93), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:59.177354 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_107_107_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:59.325799 [ 46935 ] {697de71a-c33e-4789-9060-c312145703f4} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_107_107_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r6 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49648) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r8 SELECT 94), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:59.345969 [ 46935 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_107_107_0 required_number_of_replicas: 5 actual_number_of_replicas: 2 replicas: r6 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:17:59.397145 [ 46927 ] {ff8487e9-3418-4c6d-960f-a45e6eb5fedd} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_107_107_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r4 r6 r7 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49658) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 94), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:17:59.434280 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_107_107_0 required_number_of_replicas: 5 actual_number_of_replicas: 4 replicas: r4 r6 r7 r9 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:18:00.023417 [ 46940 ] {ab80f288-c17c-407e-8284-f04b2bf703d1} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_108_108_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49810) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 95), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:18:00.044525 [ 46940 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_108_108_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:18:00.057250 [ 46934 ] {d4ac0f43-0a27-49cc-91f7-c77d6980060d} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_108_108_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49796) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 94), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:18:00.058894 [ 46927 ] {026957de-1858-49f7-ae18-793c24b08338} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_108_108_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49780) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 95), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:18:00.064499 [ 46928 ] {d8230e63-8587-4333-9edb-0f4781cac81f} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_108_108_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49822) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 95), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:18:00.076051 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_108_108_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:18:00.078815 [ 46927 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_108_108_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:18:00.088235 [ 46928 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_108_108_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:18:00.094966 [ 46938 ] {8fbf811a-ac4d-47f3-b704-0864181f6651} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_108_108_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49836) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r10 SELECT 95), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:18:00.134424 [ 46938 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_108_108_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:18:00.162798 [ 46939 ] {c7f356ce-6572-4997-84b0-da6fa67b7846} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_108_108_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49844) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r4 SELECT 94), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:18:00.182578 [ 46939 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_108_108_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:18:01.027085 [ 46934 ] {2237f8be-2636-4f05-a9d3-9063844e40ed} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_109_109_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49984) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r8 SELECT 96), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:18:01.047763 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_109_109_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:18:01.089968 [ 46940 ] {8d9cf558-f0c5-4b9a-a346-2c1372d6deb3} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_109_109_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49992) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 96), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:18:01.119323 [ 46940 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_109_109_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:18:01.202672 [ 46939 ] {57825979-2249-4384-bd9a-092c6a27e391} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_109_109_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50036) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 96), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:18:01.204752 [ 46928 ] {e722e70e-d6ae-4ffd-b3ad-b227814ab688} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_109_109_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50008) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 95), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:18:01.206005 [ 46933 ] {525a5f4a-d5a7-4edc-9532-d8a62219f9a3} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_109_109_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50046) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r10 SELECT 96), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:18:01.206522 [ 46938 ] {0ee442b8-f177-45a1-b645-630eba654a35} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_109_109_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50024) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 96), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:18:01.221333 [ 46939 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_109_109_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:18:01.222589 [ 46937 ] {25c5bab5-b1d2-4fd9-915b-e2338acd5575} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_109_109_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50054) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 96), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:18:01.225934 [ 46938 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_109_109_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:18:01.235640 [ 46933 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_109_109_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:18:01.243541 [ 46937 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_109_109_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:18:01.246774 [ 46928 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_109_109_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:18:01.258897 [ 47191 ] {11a94044-412f-4e54-b0d7-235294802c80} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_109_109_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50056) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 96), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:18:01.281346 [ 47191 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_109_109_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:18:01.307523 [ 43368 ] {1e8e996f-31a3-429c-8c9e-796bd9c7ef57} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_109_109_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r10 r2 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50072) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r4 SELECT 95), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:18:01.326291 [ 43368 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_109_109_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r10 r2 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:18:02.128986 [ 46934 ] {3a77221f-db3d-4cd5-bf3b-3deb59e35da3} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_110_110_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r3 r7 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50174) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r8 SELECT 97), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:18:02.153272 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_110_110_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r3 r7 r8 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:18:02.775490 [ 46937 ] {b39aec8a-8cf2-4c27-b99a-904b4a5e388f} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_111_111_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50286) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r1 SELECT 98), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:18:02.805768 [ 46937 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_111_111_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:18:02.840246 [ 46930 ] {ff19d5eb-41b9-41ab-8cb1-09050e4f144d} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_111_111_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50314) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r3 SELECT 98), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:18:02.842042 [ 47191 ] {81321e29-6918-41d7-bd54-35fd227aa2fa} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_111_111_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50302) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r2 SELECT 98), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:18:02.846237 [ 46929 ] {3fc203d0-5849-4360-8f0e-ff2fa9c942e3} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_111_111_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50324) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r6 SELECT 98), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:18:02.848442 [ 2135 ] {c545c3af-767c-4557-b22d-9a366fb4af12} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_111_111_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50320) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r10 SELECT 98), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:18:02.860880 [ 46929 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_111_111_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:18:02.860880 [ 47191 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_111_111_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:18:02.866305 [ 46930 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_111_111_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:18:02.869724 [ 2135 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_111_111_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:18:02.875383 [ 46934 ] {f6af2b8b-cc1c-483a-ae6a-5ca306ebbccc} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_111_111_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50332) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r5 SELECT 97), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:18:02.892027 [ 46935 ] {c7042e84-27bf-4c5b-a8f9-2eec84526f25} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_111_111_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50318) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r9 SELECT 98), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:18:02.904350 [ 46934 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_111_111_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:18:02.911057 [ 46935 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_111_111_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:18:03.614661 [ 46937 ] {dd851f56-9e61-47b2-aafc-e160a1c19d2a} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_112_112_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37842) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r4 SELECT 98), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:18:03.631237 [ 46937 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_112_112_0 required_number_of_replicas: 5 actual_number_of_replicas: 1 replicas: r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:18:03.825894 [ 47191 ] {20e38b5b-c199-4d22-bade-4926208e1e2a} executeQuery: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_112_112_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r1 r3 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37846) (comment: 01459_manual_write_to_replicas_quorum.sh) (query 1, line 1) (in query: INSERT INTO r8 SELECT 99), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 2025.06.13 09:18:03.846416 [ 47191 ] {} TCPHandler: Code: 286. DB::Exception: Quorum for previous write has not been satisfied yet. Status: version: 1 part_name: all_112_112_0 required_number_of_replicas: 5 actual_number_of_replicas: 3 replicas: r1 r3 r7 . (UNSATISFIED_QUORUM_FOR_PREVIOUS_WRITE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:274: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000003a2ffedd 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003a2fb4ff 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000003a2c5a4c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2be706 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 16. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 19. ? @ 0x00007f5206343ac3 20. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:18:27.826310 [ 34290 ] {} ExternalDictionaries: Could not update cache dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)', next update is scheduled at 2025-06-13 09:18:33: Code: 60. DB::Exception: Unknown table expression identifier 'ordinary_db.view_for_dict' in scope SELECT key_column, second_column, third_column FROM ordinary_db.view_for_dict WHERE key_column IN (496, 363). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000026edde23 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:127: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x0000000026edeb60 18. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000277239f9 19. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 21. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:18:27.829689 [ 37798 ] {} ExternalDictionaries: Could not update cache dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)', next update is scheduled at 2025-06-13 09:18:33: Code: 60. DB::Exception: Unknown table expression identifier 'ordinary_db.view_for_dict' in scope SELECT key_column, second_column, third_column FROM ordinary_db.view_for_dict WHERE key_column IN (412, 647). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000026edde23 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:127: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x0000000026edeb60 18. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000277239f9 19. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 21. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:18:27.833617 [ 34129 ] {} ExternalDictionaries: Could not update cache dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)', next update is scheduled at 2025-06-13 09:18:34: Code: 60. DB::Exception: Unknown table expression identifier 'ordinary_db.view_for_dict' in scope SELECT key_column, second_column, third_column FROM ordinary_db.view_for_dict WHERE key_column IN (278, 746). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000026edde23 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:127: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x0000000026edeb60 18. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000277239f9 19. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 21. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:18:27.837065 [ 10592 ] {} ExternalDictionaries: Could not update cache dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)', next update is scheduled at 2025-06-13 09:18:34: Code: 60. DB::Exception: Unknown table expression identifier 'ordinary_db.view_for_dict' in scope SELECT key_column, second_column, third_column FROM ordinary_db.view_for_dict WHERE key_column IN (846, 92). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000026edde23 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:127: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x0000000026edeb60 18. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000277239f9 19. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 21. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:18:28.062476 [ 43368 ] {b2f3b87b-48a4-4e04-a385-4f7d86c1ffc7} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Update failed for dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) : Code: 60. DB::Exception: Unknown table expression identifier 'ordinary_db.view_for_dict' in scope SELECT key_column, second_column, third_column FROM ordinary_db.view_for_dict WHERE key_column IN (496, 363). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000026edde23 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:127: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x0000000026edeb60 18. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000277239f9 19. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 21. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50530) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:28.062668 [ 46938 ] {d1214183-d3e9-47a4-853d-f4f3c19152a1} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:33. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50504) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:28.062768 [ 46937 ] {42624f56-e46c-43fd-bada-e1978be6512f} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:33. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50546) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:28.062852 [ 2135 ] {a3e6cf41-6244-46a4-9b7f-1c28a51e87c6} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Update failed for dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) : Code: 60. DB::Exception: Unknown table expression identifier 'ordinary_db.view_for_dict' in scope SELECT key_column, second_column, third_column FROM ordinary_db.view_for_dict WHERE key_column IN (412, 647). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000026edde23 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:127: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x0000000026edeb60 18. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000277239f9 19. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 21. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50486) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:28.063394 [ 46939 ] {790b50b0-0811-4f27-a5b9-23620dcaa8c5} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Update failed for dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) : Code: 60. DB::Exception: Unknown table expression identifier 'ordinary_db.view_for_dict' in scope SELECT key_column, second_column, third_column FROM ordinary_db.view_for_dict WHERE key_column IN (278, 746). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000026edde23 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:127: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x0000000026edeb60 18. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000277239f9 19. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 21. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50520) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:28.063489 [ 46929 ] {36f75994-2a2c-4c4b-88fa-47ce74f5f057} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Update failed for dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) : Code: 60. DB::Exception: Unknown table expression identifier 'ordinary_db.view_for_dict' in scope SELECT key_column, second_column, third_column FROM ordinary_db.view_for_dict WHERE key_column IN (846, 92). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000026edde23 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:127: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x0000000026edeb60 18. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000277239f9 19. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 21. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50498) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:28.082152 [ 43368 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Update failed for dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) : Code: 60. DB::Exception: Unknown table expression identifier 'ordinary_db.view_for_dict' in scope SELECT key_column, second_column, third_column FROM ordinary_db.view_for_dict WHERE key_column IN (496, 363). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000026edde23 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:127: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x0000000026edeb60 18. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000277239f9 19. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 21. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:28.082165 [ 46938 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:33. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:28.088378 [ 46937 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:33. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:28.089350 [ 2135 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Update failed for dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) : Code: 60. DB::Exception: Unknown table expression identifier 'ordinary_db.view_for_dict' in scope SELECT key_column, second_column, third_column FROM ordinary_db.view_for_dict WHERE key_column IN (412, 647). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000026edde23 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:127: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x0000000026edeb60 18. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000277239f9 19. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 21. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:28.090751 [ 46929 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Update failed for dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) : Code: 60. DB::Exception: Unknown table expression identifier 'ordinary_db.view_for_dict' in scope SELECT key_column, second_column, third_column FROM ordinary_db.view_for_dict WHERE key_column IN (846, 92). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000026edde23 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:127: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x0000000026edeb60 18. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000277239f9 19. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 21. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:28.091709 [ 46939 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Update failed for dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) : Code: 60. DB::Exception: Unknown table expression identifier 'ordinary_db.view_for_dict' in scope SELECT key_column, second_column, third_column FROM ordinary_db.view_for_dict WHERE key_column IN (278, 746). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000026edde23 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:127: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x0000000026edeb60 18. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000277239f9 19. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 21. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:28.936784 [ 2135 ] {16f66171-d0f8-4417-b53a-c1b34728c1e2} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50552) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:28.958199 [ 2135 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:28.958318 [ 46929 ] {94bf7539-f91c-4691-a902-54c24918f321} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50566) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:28.958413 [ 43368 ] {66acaee1-977e-4fb3-b030-3a96bd3e36d7} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50600) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:28.958511 [ 46936 ] {3fc94b27-5cd0-455d-be1f-f503010ba642} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50606) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:28.959210 [ 46938 ] {29bec4c0-6871-413f-b214-7d98cd67b625} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50580) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:28.976627 [ 46929 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:28.976634 [ 46938 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:28.976676 [ 46936 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:28.976917 [ 43368 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:28.988920 [ 46939 ] {2605bce5-e638-48ab-befb-08041939c15f} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50584) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:29.013571 [ 46939 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:29.919231 [ 2135 ] {8f2b460e-8c26-44fd-bf79-2a64c0de6374} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50610) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:29.926906 [ 46929 ] {32c6ac02-a440-4cfd-9b5b-23920d6f0dff} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50614) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:29.936420 [ 2135 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:29.943456 [ 46938 ] {50d2b18c-8a46-45a8-a2fe-2dc3e992ce47} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50616) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:29.945011 [ 46929 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:29.952712 [ 43368 ] {c5d069c2-1446-4fed-b0f0-f6366460c7b6} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50628) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:29.961613 [ 46938 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:29.970575 [ 43368 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:29.975024 [ 46936 ] {18bd42a6-8508-4f17-a039-a509f4cfd7e0} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50644) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:29.978800 [ 46939 ] {6e64232c-c13c-491d-aa84-955da76f9a06} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50620) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:29.992558 [ 46936 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:29.997152 [ 46939 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:30.908161 [ 2135 ] {ca01e2f0-9880-4824-839c-24f83925c532} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50646) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:30.918247 [ 46929 ] {e4bc494a-9855-44c9-97e7-b5970832c909} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50650) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:30.925513 [ 2135 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:30.928966 [ 46939 ] {6846481b-a462-4e0a-8969-404a6b4e9b92} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50664) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:30.937750 [ 46929 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:30.940144 [ 46938 ] {8609bb35-8f46-4482-8606-ea394b69c7bd} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50658) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:30.947020 [ 46939 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:30.957667 [ 46938 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:30.974255 [ 43368 ] {4fbba87d-1a5d-4089-b1ae-ddbfe430fded} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50672) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:30.988565 [ 46936 ] {ac2fe0bf-9049-4e86-b8e9-2183a61a0133} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50678) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:30.993087 [ 43368 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:31.007405 [ 46936 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:31.884986 [ 2135 ] {80915109-556b-4566-9560-5ffec67593b9} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50694) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:31.902631 [ 2135 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:31.921079 [ 46929 ] {dd56ea80-0356-40af-9dcb-a83d01301e21} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50700) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:31.935143 [ 46939 ] {c6e759ba-d708-41f6-8fee-768b0e0f0f27} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50716) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:31.939130 [ 46929 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:31.946924 [ 46938 ] {e47cb63e-68b0-406c-a5d5-b3172e373f1b} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50712) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:31.957471 [ 46939 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:31.963079 [ 43368 ] {e3f81962-8c0f-4932-921f-1e25a4347de1} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50718) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:31.964637 [ 46936 ] {ce07cfd5-f58b-433e-8796-a270e4a0c5c3} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50732) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:31.965973 [ 46938 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:31.981087 [ 43368 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:31.981251 [ 46936 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:32.890704 [ 46939 ] {f7594e95-ff3b-4568-a6e0-c63198461b99} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50754) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:32.908280 [ 46939 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:32.912626 [ 46936 ] {aa60f75a-48e3-4a59-8336-fae4947465bf} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50780) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:32.915424 [ 46938 ] {7f36c835-ddde-4ac8-a7d4-423b166f27ed} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50748) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:32.918263 [ 43368 ] {cf3970d9-205a-4871-b383-5b8db5c05c4b} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50770) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:32.930235 [ 46936 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:32.932557 [ 46938 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:32.938930 [ 43368 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:32.949713 [ 46937 ] {93b24a19-3435-470f-bf5c-4b43c107f9ff} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50784) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:32.960328 [ 47191 ] {0d95825d-0af2-4aac-aa35-ed53c21b413f} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50800) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:32.969043 [ 46937 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:32.983396 [ 47191 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:33.880899 [ 46939 ] {396c2416-5e77-421e-a392-66d0c62a7c02} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47618) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:33.896553 [ 43368 ] {65db04b8-428d-423b-bdbb-e5e42ea405da} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47622) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:33.896966 [ 46938 ] {4b104584-388c-45b6-a350-1eeebc684b67} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47614) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:33.898249 [ 46939 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:33.911671 [ 46937 ] {69abceef-86f8-4236-9517-8d2fe9a672a6} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47636) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:33.913377 [ 46936 ] {f913d393-b895-41ea-b1a1-45026da60baf} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47626) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:33.915282 [ 46938 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:33.921771 [ 43368 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:33.929495 [ 46937 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:33.931165 [ 46936 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:33.954979 [ 47191 ] {4e95f563-6ca9-4c3c-99e6-8d832acaf975} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47646) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:33.975867 [ 47191 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:34. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:39.329853 [ 34290 ] {} ExternalDictionaries: Could not update cache dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)', next update is scheduled at 2025-06-13 09:18:45: Code: 60. DB::Exception: Unknown table expression identifier 'ordinary_db.table_for_dict_real' in scope SELECT key_column, second_column, third_column FROM ordinary_db.table_for_dict_real WHERE sleepEachRow(1) = 0. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032612b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8db2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./build_docker/./src/Storages/StorageView.cpp:176: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038da1717 15. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032b6f004 16. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032b5101c 17. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x0000000032afc62e 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000026edde23 23. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:127: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x0000000026edeb60 24. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000277239f9 25. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 27. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:18:39.332969 [ 37798 ] {} ExternalDictionaries: Could not update cache dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)', next update is scheduled at 2025-06-13 09:18:46: Code: 60. DB::Exception: Unknown table expression identifier 'ordinary_db.table_for_dict_real' in scope SELECT key_column, second_column, third_column FROM ordinary_db.table_for_dict_real WHERE sleepEachRow(1) = 0. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032612b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8db2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./build_docker/./src/Storages/StorageView.cpp:176: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038da1717 15. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032b6f004 16. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032b5101c 17. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x0000000032afc62e 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000026edde23 23. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:127: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x0000000026edeb60 24. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000277239f9 25. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 27. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:18:39.340341 [ 46939 ] {368056cc-add1-4b50-936b-a96b04cf3db5} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Update failed for dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) : Code: 60. DB::Exception: Unknown table expression identifier 'ordinary_db.table_for_dict_real' in scope SELECT key_column, second_column, third_column FROM ordinary_db.table_for_dict_real WHERE sleepEachRow(1) = 0. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032612b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8db2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./build_docker/./src/Storages/StorageView.cpp:176: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038da1717 15. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032b6f004 16. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032b5101c 17. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x0000000032afc62e 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000026edde23 23. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:127: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x0000000026edeb60 24. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000277239f9 25. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 27. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47770) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:39.340937 [ 46930 ] {0829bbf4-2dea-42f7-9f90-d01cce1c8257} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:46. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47788) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:39.344754 [ 43368 ] {831860d0-c8bd-4ec1-924d-6602c4bc8f4b} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Update failed for dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) : Code: 60. DB::Exception: Unknown table expression identifier 'ordinary_db.table_for_dict_real' in scope SELECT key_column, second_column, third_column FROM ordinary_db.table_for_dict_real WHERE sleepEachRow(1) = 0. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032612b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8db2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./build_docker/./src/Storages/StorageView.cpp:176: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038da1717 15. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032b6f004 16. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032b5101c 17. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x0000000032afc62e 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000026edde23 23. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:127: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x0000000026edeb60 24. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000277239f9 25. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 27. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47776) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:39.366334 [ 46930 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:46. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:39.367006 [ 46939 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Update failed for dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) : Code: 60. DB::Exception: Unknown table expression identifier 'ordinary_db.table_for_dict_real' in scope SELECT key_column, second_column, third_column FROM ordinary_db.table_for_dict_real WHERE sleepEachRow(1) = 0. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032612b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8db2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./build_docker/./src/Storages/StorageView.cpp:176: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038da1717 15. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032b6f004 16. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032b5101c 17. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x0000000032afc62e 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000026edde23 23. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:127: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x0000000026edeb60 24. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000277239f9 25. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 27. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:39.368391 [ 43368 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Update failed for dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) : Code: 60. DB::Exception: Unknown table expression identifier 'ordinary_db.table_for_dict_real' in scope SELECT key_column, second_column, third_column FROM ordinary_db.table_for_dict_real WHERE sleepEachRow(1) = 0. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032612b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8db2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./build_docker/./src/Storages/StorageView.cpp:176: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038da1717 15. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032b6f004 16. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032b5101c 17. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x0000000032afc62e 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000026edde23 23. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:127: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x0000000026edeb60 24. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000277239f9 25. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 27. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:39.405136 [ 34290 ] {} ExternalDictionaries: Could not update cache dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)', next update is scheduled at 2025-06-13 09:18:44: Code: 60. DB::Exception: Unknown table expression identifier 'ordinary_db.table_for_dict_real' in scope SELECT key_column, second_column, third_column FROM ordinary_db.table_for_dict_real WHERE sleepEachRow(1) = 0. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032612b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8db2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./build_docker/./src/Storages/StorageView.cpp:176: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038da1717 15. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032b6f004 16. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032b5101c 17. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x0000000032afc62e 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000026edde23 23. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:127: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x0000000026edeb60 24. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000277239f9 25. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 27. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:18:39.414765 [ 46936 ] {57ddd1fd-474b-4079-8c26-682d918096dc} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Update failed for dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) : Code: 60. DB::Exception: Unknown table expression identifier 'ordinary_db.table_for_dict_real' in scope SELECT key_column, second_column, third_column FROM ordinary_db.table_for_dict_real WHERE sleepEachRow(1) = 0. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032612b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8db2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./build_docker/./src/Storages/StorageView.cpp:176: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038da1717 15. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032b6f004 16. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032b5101c 17. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x0000000032afc62e 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000026edde23 23. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:127: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x0000000026edeb60 24. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000277239f9 25. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 27. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47782) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:39.434518 [ 46936 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Update failed for dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) : Code: 60. DB::Exception: Unknown table expression identifier 'ordinary_db.table_for_dict_real' in scope SELECT key_column, second_column, third_column FROM ordinary_db.table_for_dict_real WHERE sleepEachRow(1) = 0. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032612b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8db2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./build_docker/./src/Storages/StorageView.cpp:176: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038da1717 15. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032b6f004 16. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032b5101c 17. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x0000000032afc62e 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000026edde23 23. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:127: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x0000000026edeb60 24. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000277239f9 25. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 27. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:40.221536 [ 46935 ] {5720a603-2296-465e-9058-e242436b8db9} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47818) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:40.229699 [ 46930 ] {7b198373-8003-47d8-8800-149a47f8852c} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47804) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:40.240487 [ 46935 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:40.244131 [ 46934 ] {4550659d-d272-4092-97d8-b771709e12fd} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47838) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:40.244229 [ 46932 ] {498dbad2-443e-4026-87b7-c15bd2917115} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47834) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:40.247154 [ 46930 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:40.261705 [ 46932 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:40.262392 [ 46934 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:40.343375 [ 46940 ] {ce00bae1-7897-4a47-9d37-0ab98f584a9f} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47854) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:40.373168 [ 46940 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:40.390152 [ 46928 ] {90d609fd-7d0f-4607-85d1-61fbdd3ecfde} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47864) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:40.406206 [ 46928 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:41.163630 [ 46930 ] {af3ce2b6-a4fa-46f5-86ce-8e4344a10f28} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47868) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:41.173938 [ 46935 ] {d9e40733-f9e0-4ad1-a5be-d393ccd1bef0} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47872) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:41.180648 [ 46930 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:41.190372 [ 46935 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:41.197621 [ 46932 ] {aea836cd-9dc9-4ac1-8a51-768d9b4c5250} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47874) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:41.216318 [ 46932 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:41.219038 [ 46934 ] {317f3d7d-df94-4f98-b6ec-614df3988f94} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47882) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:41.236395 [ 46934 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:41.347026 [ 46928 ] {5adc4627-e8de-44d3-95f3-b27e754acc3e} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47900) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:41.349881 [ 46940 ] {7e2e6ecd-9cfb-43ce-a461-94871f67ba29} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47894) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:41.362593 [ 46928 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:41.362803 [ 46940 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:42.121877 [ 46930 ] {32dddcdc-c340-4b86-81c2-39b65e9e33d3} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47914) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:42.141267 [ 46930 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:42.146635 [ 46932 ] {4fc2da93-bd00-43b0-885b-90e32ee9971b} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47934) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:42.147849 [ 46935 ] {642d81ca-6933-49b2-95ed-a5337112276b} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47918) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:42.163917 [ 46932 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:42.171612 [ 46935 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:42.185203 [ 46934 ] {bfec8f60-791f-4f67-9b8f-7e43bf5f7e8f} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47942) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:42.202808 [ 46934 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:42.298990 [ 46940 ] {d16e7e75-8ac7-4048-9f1c-218ca3c3092b} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47958) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:42.309044 [ 46928 ] {771b3b1d-eee5-4852-bb1b-1867186bd018} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47974) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:42.327348 [ 46940 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:42.332491 [ 46928 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:43.098002 [ 46930 ] {28eb0d6e-7381-48bd-beeb-14f92f190985} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47978) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:43.115351 [ 46930 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:43.120036 [ 46932 ] {5bb41dff-660f-47ab-96ab-b88e8065fec2} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47992) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:43.120508 [ 46935 ] {483d1368-dcf9-41bf-b8e3-4cc0abcda571} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47984) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:43.141019 [ 46932 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:43.141065 [ 46935 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:43.182817 [ 46934 ] {fb2b677b-ee51-4590-8d48-0b52fe27af79} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48004) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:43.202836 [ 46934 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:43.291719 [ 46928 ] {a201d6c7-8dad-460d-b0ce-98c3f0355a0c} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59202) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:43.294668 [ 46940 ] {bb5ab558-9c89-4ee7-b2e5-61aebc432bf9} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59200) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:43.309193 [ 46928 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:43.319662 [ 46940 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:44.098393 [ 46930 ] {871853d8-8ec8-473c-9242-30280b8f6131} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59218) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:44.116224 [ 46932 ] {ab99cc1e-dd36-4063-9fb7-ce5746c6b97f} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59242) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:44.116779 [ 46930 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:44.117551 [ 46935 ] {04d1d690-0e5a-44e3-b65d-2d324cfea462} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59226) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:44.132234 [ 46932 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:44.140715 [ 46935 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:44.171940 [ 46934 ] {c819613d-b29a-4259-833f-cada0fb0097a} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59258) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:44.187918 [ 46934 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:44.259777 [ 46940 ] {28500545-c2b8-49c8-9070-b5b90497dc96} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59274) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:44.278183 [ 46940 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:44.287409 [ 46928 ] {d6dcad87-66de-402e-b9da-1d270a73f782} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59282) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:44.305934 [ 46928 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:44. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:45.098926 [ 34290 ] {} ExternalDictionaries: Could not update cache dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)', next update is scheduled at 2025-06-13 09:18:51: Code: 60. DB::Exception: Unknown table expression identifier 'ordinary_db.table_for_dict_real' in scope SELECT key_column, second_column, third_column FROM ordinary_db.table_for_dict_real WHERE sleepEachRow(1) = 0. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032612b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8db2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./build_docker/./src/Storages/StorageView.cpp:176: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038da1717 15. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032b6f004 16. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032b5101c 17. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x0000000032afc62e 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000026edde23 23. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:127: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x0000000026edeb60 24. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000277239f9 25. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 27. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:18:45.107846 [ 46930 ] {474806e2-33ad-432c-b439-ad951983d11e} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Update failed for dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) : Code: 60. DB::Exception: Unknown table expression identifier 'ordinary_db.table_for_dict_real' in scope SELECT key_column, second_column, third_column FROM ordinary_db.table_for_dict_real WHERE sleepEachRow(1) = 0. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032612b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8db2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./build_docker/./src/Storages/StorageView.cpp:176: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038da1717 15. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032b6f004 16. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032b5101c 17. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x0000000032afc62e 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000026edde23 23. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:127: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x0000000026edeb60 24. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000277239f9 25. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 27. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59298) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:45.132860 [ 10592 ] {} ExternalDictionaries: Could not update cache dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)', next update is scheduled at 2025-06-13 09:18:53: Code: 60. DB::Exception: Unknown table expression identifier 'ordinary_db.table_for_dict_real' in scope SELECT key_column, second_column, third_column FROM ordinary_db.table_for_dict_real WHERE sleepEachRow(1) = 0. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032612b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8db2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./build_docker/./src/Storages/StorageView.cpp:176: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038da1717 15. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032b6f004 16. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032b5101c 17. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x0000000032afc62e 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000026edde23 23. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:127: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x0000000026edeb60 24. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000277239f9 25. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 27. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:18:45.133648 [ 46930 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Update failed for dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) : Code: 60. DB::Exception: Unknown table expression identifier 'ordinary_db.table_for_dict_real' in scope SELECT key_column, second_column, third_column FROM ordinary_db.table_for_dict_real WHERE sleepEachRow(1) = 0. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032612b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8db2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./build_docker/./src/Storages/StorageView.cpp:176: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038da1717 15. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032b6f004 16. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032b5101c 17. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x0000000032afc62e 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000026edde23 23. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:127: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x0000000026edeb60 24. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000277239f9 25. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 27. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:45.134927 [ 37798 ] {} ExternalDictionaries: Could not update cache dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)', next update is scheduled at 2025-06-13 09:18:57: Code: 60. DB::Exception: Unknown table expression identifier 'ordinary_db.table_for_dict_real' in scope SELECT key_column, second_column, third_column FROM ordinary_db.table_for_dict_real WHERE sleepEachRow(1) = 0. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032612b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8db2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./build_docker/./src/Storages/StorageView.cpp:176: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038da1717 15. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032b6f004 16. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032b5101c 17. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x0000000032afc62e 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000026edde23 23. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:127: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x0000000026edeb60 24. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000277239f9 25. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 27. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:18:45.141254 [ 46932 ] {d6b650fa-6d95-4065-bba6-793d5ed4e0d0} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Update failed for dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) : Code: 60. DB::Exception: Unknown table expression identifier 'ordinary_db.table_for_dict_real' in scope SELECT key_column, second_column, third_column FROM ordinary_db.table_for_dict_real WHERE sleepEachRow(1) = 0. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032612b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8db2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./build_docker/./src/Storages/StorageView.cpp:176: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038da1717 15. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032b6f004 16. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032b5101c 17. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x0000000032afc62e 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000026edde23 23. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:127: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x0000000026edeb60 24. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000277239f9 25. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 27. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59314) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:45.143630 [ 46935 ] {3e6f9d24-4a8e-4c88-b507-8f542216d23f} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Update failed for dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) : Code: 60. DB::Exception: Unknown table expression identifier 'ordinary_db.table_for_dict_real' in scope SELECT key_column, second_column, third_column FROM ordinary_db.table_for_dict_real WHERE sleepEachRow(1) = 0. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032612b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8db2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./build_docker/./src/Storages/StorageView.cpp:176: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038da1717 15. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032b6f004 16. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032b5101c 17. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x0000000032afc62e 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000026edde23 23. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:127: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x0000000026edeb60 24. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000277239f9 25. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 27. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59306) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:45.147185 [ 46934 ] {4ed245c2-0916-40e2-84b4-6502395cd2d1} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:57. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59326) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:45.162271 [ 46935 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Update failed for dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) : Code: 60. DB::Exception: Unknown table expression identifier 'ordinary_db.table_for_dict_real' in scope SELECT key_column, second_column, third_column FROM ordinary_db.table_for_dict_real WHERE sleepEachRow(1) = 0. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032612b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8db2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./build_docker/./src/Storages/StorageView.cpp:176: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038da1717 15. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032b6f004 16. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032b5101c 17. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x0000000032afc62e 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000026edde23 23. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:127: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x0000000026edeb60 24. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000277239f9 25. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 27. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:45.163149 [ 46934 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:57. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:45.163647 [ 46932 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Update failed for dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) : Code: 60. DB::Exception: Unknown table expression identifier 'ordinary_db.table_for_dict_real' in scope SELECT key_column, second_column, third_column FROM ordinary_db.table_for_dict_real WHERE sleepEachRow(1) = 0. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003032612b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000303c8db2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c8c5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 14. ./build_docker/./src/Storages/StorageView.cpp:176: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038da1717 15. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032b6f004 16. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032b5101c 17. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x0000000032afc62e 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 22. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000026edde23 23. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:127: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x0000000026edeb60 24. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000277239f9 25. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 27. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:45.257047 [ 46928 ] {cd4e92df-8f81-4163-8d4a-f8f9cfa06356} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:57. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59344) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:45.263435 [ 46940 ] {08129625-afaf-4057-a4e7-17a047cfdcd8} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:57. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59336) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:45.279632 [ 46928 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:57. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:45.280175 [ 46940 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:57. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:46.072936 [ 46932 ] {bb75ad4b-4a1d-4fe9-8590-38d8ef12e782} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:57. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59374) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:46.089910 [ 46932 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:57. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:46.103429 [ 46935 ] {0797737b-cf1f-44a1-9ffe-d18d8f3b368f} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:57. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59358) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:46.103443 [ 46940 ] {20204168-4ab9-4332-9951-786a8d2fc877} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:57. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59386) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:46.105669 [ 46934 ] {e3fc0e12-a2a3-4fa7-9167-9f5ecb13a02c} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:57. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59376) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:46.119994 [ 46935 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:57. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:46.120004 [ 46940 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:57. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:46.120198 [ 46934 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:57. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:46.229314 [ 46933 ] {5045b25e-4b41-426b-bf0f-e673faea0fbe} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:57. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59392) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:46.231960 [ 46928 ] {99f4330c-33ab-4a20-95b1-2b72f979789d} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:57. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59388) (comment: 01412_cache_dictionary_race.sh) (query 1, line 1) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 2025.06.13 09:18:46.249855 [ 46933 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:57. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:46.253907 [ 46928 ] {} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (a4abd298-7c9f-4492-a1ab-6b93a32627a8) now, because nearest update is scheduled at 2025-06-13 09:18:57. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000027728727 5. void std::__function::__policy_invoker>)>::__call_impl[abi:ne190107]::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x0000000027751d11 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002775873b 7. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002775e3df 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:42: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::CacheDictionaryUpdateQueue(String, DB::CacheDictionaryUpdateQueueConfiguration, std::function>)>&&) @ 0x0000000027756752 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration) @ 0x000000002771112f 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> DB::createCacheDictionaryLayout<(DB::DictionaryKeyType)0, false>(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool) @ 0x000000002762db11 7. ./build_docker/./src/Dictionaries/registerCacheDictionaries.cpp:265: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002762adee 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000090971fa 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000908cdef 12. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 28. ? @ 0x00007f5206343ac3 29. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000277583c8 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027717904 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x0000000027714b18 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090f940c 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffecfb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb767 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff5926 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031a89be5 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003ba0f274 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 25. ? @ 0x00007f5206343ac3 26. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:18:51.648087 [ 46935 ] {bf0922e3-07de-4492-a56f-c62a9d378197} executeQuery: Code: 36. DB::Exception: Dictionary (`default.countryId`) not found: In scope SELECT dictGet('default.countryId', 'country', toUInt64(number)) AS country FROM numbers(2) GROUP BY country. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59416) (comment: 01376_GROUP_BY_injective_elimination_dictGet.sql) (query 1, line 3) (in query: -- https://github.com/ClickHouse/ClickHouse/issues/11469 SELECT dictGet('default.countryId', 'country', toUInt64(number)) AS country FROM numbers(2) GROUP BY country;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:168: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x00000000327c0432 5. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:113: DB::ExternalDictionariesLoader::getDictionaryStructure(String const&, std::shared_ptr) const @ 0x00000000327c17d3 6. DB::FunctionDictHelper::getDictionaryStructure(String const&) const @ 0x00000000090a5207 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009093e7c 8. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 09:18:51.656417 [ 46935 ] {} TCPHandler: Code: 36. DB::Exception: Dictionary (`default.countryId`) not found: In scope SELECT dictGet('default.countryId', 'country', toUInt64(number)) AS country FROM numbers(2) GROUP BY country. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:168: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x00000000327c0432 5. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:113: DB::ExternalDictionariesLoader::getDictionaryStructure(String const&, std::shared_ptr) const @ 0x00000000327c17d3 6. DB::FunctionDictHelper::getDictionaryStructure(String const&) const @ 0x00000000090a5207 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000009093e7c 8. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000de95ebf 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002bff8bbe 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002bff7fa1 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002bff97d8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030385da8 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000303263d0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000303233fa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c1e80 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c9d6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 2025.06.13 09:19:07.277441 [ 46935 ] {29ef0aa3-78db-43e5-92c4-8e1e7e3854d9} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: In scope SELECT dictGetUInt64('db_01268.dict1', 'second_column', toUInt64(100500)). (TOO_MANY_ROWS_OR_BYTES) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41162) (comment: 01268_dictionary_direct_layout.sql) (query 54, line 119) (in query: SELECT dictGetUInt64('db_01268.dict1', 'second_column', toUInt64(100500));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002f24bdb7 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f2479c8 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f247bac 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000003ba4b81f 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 13. DB::SourceFromQueryPipeline::generate() @ 0x0000000027934320 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b0f6008 21. DB::DirectDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000002790d5a5 22. DB::DirectDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000279156d8 23. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 24. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 25. DB::FunctionDictGetImpl, DB::NameDictGetUInt64, (DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090dca2c 26. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 27. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 28. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 29. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 30. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 31. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 2025.06.13 09:19:07.285051 [ 46935 ] {} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: In scope SELECT dictGetUInt64('db_01268.dict1', 'second_column', toUInt64(100500)). (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002f24bdb7 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f2479c8 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f247bac 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000003ba4b81f 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000026eb3c04 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b075be1 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 13. DB::SourceFromQueryPipeline::generate() @ 0x0000000027934320 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b0f6008 21. DB::DirectDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000002790d5a5 22. DB::DirectDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000279156d8 23. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000909924e 24. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009090ad1 25. DB::FunctionDictGetImpl, DB::NameDictGetUInt64, (DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000090dca2c 26. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008b9c722 27. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002bffeddb 28. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb5e3 29. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfea432 30. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bfeb4b3 31. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002bff06bd 2025.06.13 09:20:57.948186 [ 46932 ] {b9e41909-f228-48cd-b68f-49f7119d3eb7} executeQuery: Code: 48. DB::Exception: Value 6 of setting distributed_ddl_entry_format_version is incompatible with cross-replication. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54610) (comment: 01152_cross_replication.sql) (query 7, line 11) (in query: CREATE TABLE demo_loan_01568 ON CLUSTER test_cluster_two_shards_different_databases ( `id` Int64 COMMENT 'id', `date_stat` Date COMMENT 'date of stat', `customer_no` String COMMENT 'customer no', `loan_principal` Float64 COMMENT 'loan principal' ) ENGINE=ReplacingMergeTree() ORDER BY id PARTITION BY toYYYYMM(date_stat);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000d04bc6a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2273: DB::InterpreterCreateQuery::prepareOnClusterQuery(DB::ASTCreateQuery&, std::shared_ptr, String const&) @ 0x000000003292b465 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2311: DB::InterpreterCreateQuery::executeQueryOnCluster(DB::ASTCreateQuery&) @ 0x0000000032909454 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1729: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000032901fa4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:20:57.956318 [ 46932 ] {} TCPHandler: Code: 48. DB::Exception: Value 6 of setting distributed_ddl_entry_format_version is incompatible with cross-replication. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000d04bc6a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2273: DB::InterpreterCreateQuery::prepareOnClusterQuery(DB::ASTCreateQuery&, std::shared_ptr, String const&) @ 0x000000003292b465 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2311: DB::InterpreterCreateQuery::executeQueryOnCluster(DB::ASTCreateQuery&) @ 0x0000000032909454 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1729: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000032901fa4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:20:58.133769 [ 1186 ] {} DDLWorker: There are two the same ClickHouse instances in task query-0000000004: localhost:9000 and localhost:9000. Will use the first one only. 2025.06.13 09:20:58.152159 [ 1186 ] {} DDLWorker: Cannot parse DDL task query-0000000004: Cannot parse query or obtain cluster info. Will try to send error status: Code: 371. DB::Exception: For a distributed DDL on circular replicated cluster its table name must be qualified by database name. (INCONSISTENT_CLUSTER_DEFINITION) (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:20:58.386288 [ 46932 ] {d5fb5721-6d66-43ad-a1af-589a5f16a88d} executeQuery: Code: 371. DB::Exception: There was an error on [localhost:9000]: Code: 371. DB::Exception: For a distributed DDL on circular replicated cluster its table name must be qualified by database name. (INCONSISTENT_CLUSTER_DEFINITION) (version 25.3.3.20286.altinityantalya (altinity build)). (INCONSISTENT_CLUSTER_DEFINITION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54610) (comment: 01152_cross_replication.sql) (query 9, line 13) (in query: CREATE TABLE demo_loan_01568 ON CLUSTER test_cluster_two_shards_different_databases ( `id` Int64 COMMENT 'id', `date_stat` Date COMMENT 'date of stat', `customer_no` String COMMENT 'customer no', `loan_principal` Float64 COMMENT 'loan principal' ) ENGINE=ReplacingMergeTree() ORDER BY id PARTITION BY toYYYYMM(date_stat);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x0000000033702871 4. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x0000000031a69b8a 5. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 6. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 11. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:20:58.395733 [ 46932 ] {} TCPHandler: Code: 371. DB::Exception: There was an error on [localhost:9000]: Code: 371. DB::Exception: For a distributed DDL on circular replicated cluster its table name must be qualified by database name. (INCONSISTENT_CLUSTER_DEFINITION) (version 25.3.3.20286.altinityantalya (altinity build)). (INCONSISTENT_CLUSTER_DEFINITION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x0000000033702871 4. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x0000000031a69b8a 5. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b07da2c 6. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b07d28c 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 11. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:20:58.564642 [ 1186 ] {} DDLWorker: There are two the same ClickHouse instances in task query-0000000005: localhost:9000 and localhost:9000. Will use the first one only. 2025.06.13 09:20:59.005252 [ 1186 ] {} DDLWorker: There are two the same ClickHouse instances in task query-0000000006: localhost:9000 and localhost:9000. Will use the first one only. 2025.06.13 09:21:07.653598 [ 46928 ] {87cc401b-07ff-486b-b174-b99e77659a9b} executeQuery: Code: 81. DB::Exception: Database test_01150 does not exist. (UNKNOWN_DATABASE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59284) (comment: 01150_ddl_guard_rwr.sh) (query 1, line 1) (in query: RENAME TABLE test_01150.t1 TO test_01150.t2_tmp, test_01150.t2 TO test_01150.t1, test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:115: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a016f6 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:21:07.659582 [ 46928 ] {} TCPHandler: Code: 81. DB::Exception: Database test_01150 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:115: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a016f6 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:21:08.502635 [ 46928 ] {73660e09-b779-478c-b2cd-2aba09191fe8} executeQuery: Code: 57. DB::Exception: Table test_01150.t1 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59294) (comment: 01150_ddl_guard_rwr.sh) (query 1, line 1) (in query: RENAME TABLE test_01150.t2 TO test_01150.t1, test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002e99856a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a098cf 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a015af 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:21:08.511863 [ 46928 ] {} TCPHandler: Code: 57. DB::Exception: Table test_01150.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002e99856a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a098cf 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a015af 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:21:09.300333 [ 46928 ] {95811619-a0e3-4fbb-9104-7939000fcf20} executeQuery: Code: 81. DB::Exception: Database test_01150 does not exist. (UNKNOWN_DATABASE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59310) (comment: 01150_ddl_guard_rwr.sh) (query 1, line 1) (in query: RENAME TABLE test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:115: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a016f6 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:21:09.309977 [ 46928 ] {} TCPHandler: Code: 81. DB::Exception: Database test_01150 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:115: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a016f6 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:21:10.997572 [ 46928 ] {132dadb1-14cd-42fd-9ed0-8e9d20093756} executeQuery: Code: 57. DB::Exception: Table test_01150.t1 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59350) (comment: 01150_ddl_guard_rwr.sh) (query 1, line 1) (in query: RENAME TABLE test_01150.t2 TO test_01150.t1, test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002e99856a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a098cf 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a015af 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:21:11.007425 [ 46928 ] {} TCPHandler: Code: 57. DB::Exception: Table test_01150.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002e99856a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a098cf 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a015af 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:21:11.835512 [ 46932 ] {fc27bf46-cb74-4470-8629-65a7c471df47} executeQuery: Code: 81. DB::Exception: Database test_01150 does not exist. (UNKNOWN_DATABASE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59360) (comment: 01150_ddl_guard_rwr.sh) (query 1, line 1) (in query: RENAME TABLE test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:115: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a016f6 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:21:11.845159 [ 46932 ] {} TCPHandler: Code: 81. DB::Exception: Database test_01150 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:115: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a016f6 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:21:12.012229 [ 410 ] {} CgroupsReader: Cannot find 'kernel' in '/sys/fs/cgroup/memory.stat' (skipped 5901 similar messages) 2025.06.13 09:21:13.591668 [ 46932 ] {2426fc12-e998-4635-a28a-fa6ca42b807a} executeQuery: Code: 81. DB::Exception: Database test_01150 does not exist. (UNKNOWN_DATABASE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48846) (comment: 01150_ddl_guard_rwr.sh) (query 1, line 1) (in query: RENAME TABLE test_01150.t2 TO test_01150.t1, test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:115: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a016f6 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:21:13.602669 [ 46932 ] {} TCPHandler: Code: 81. DB::Exception: Database test_01150 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:115: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a016f6 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:21:14.400695 [ 46932 ] {36fd7b89-ace5-49aa-8750-8f6ce282b2b3} executeQuery: Code: 57. DB::Exception: Table test_01150.t2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48858) (comment: 01150_ddl_guard_rwr.sh) (query 1, line 1) (in query: RENAME TABLE test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002e99856a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a098cf 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a015af 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:21:14.410060 [ 46932 ] {} TCPHandler: Code: 57. DB::Exception: Table test_01150.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002e99856a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a098cf 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a015af 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:21:15.165420 [ 46932 ] {b89c4969-90db-4dd3-839d-4a0abbf29bfe} executeQuery: Code: 81. DB::Exception: Database test_01150 does not exist. (UNKNOWN_DATABASE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48886) (comment: 01150_ddl_guard_rwr.sh) (query 1, line 1) (in query: RENAME TABLE test_01150.t1 TO test_01150.t2_tmp, test_01150.t2 TO test_01150.t1, test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:115: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a016f6 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:21:15.174253 [ 46932 ] {} TCPHandler: Code: 81. DB::Exception: Database test_01150 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:115: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a016f6 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:21:15.943440 [ 46932 ] {f031eb6c-a277-4e69-a06c-8880185bd147} executeQuery: Code: 57. DB::Exception: Table test_01150.t1 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48906) (comment: 01150_ddl_guard_rwr.sh) (query 1, line 1) (in query: RENAME TABLE test_01150.t2 TO test_01150.t1, test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002e99856a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a098cf 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a015af 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:21:15.952084 [ 46932 ] {} TCPHandler: Code: 57. DB::Exception: Table test_01150.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002e99856a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a098cf 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a015af 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:21:16.706637 [ 46932 ] {39d547a5-f4d4-41ec-ba1c-54b4fb966720} executeQuery: Code: 81. DB::Exception: Database test_01150 does not exist. (UNKNOWN_DATABASE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48926) (comment: 01150_ddl_guard_rwr.sh) (query 1, line 1) (in query: RENAME TABLE test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:115: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a016f6 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:21:16.715238 [ 46932 ] {} TCPHandler: Code: 81. DB::Exception: Database test_01150 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:115: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a016f6 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:21:18.389679 [ 46932 ] {e070cdd3-64b1-4379-9e1f-f85321eb7347} executeQuery: Code: 81. DB::Exception: Database test_01150 does not exist. (UNKNOWN_DATABASE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48954) (comment: 01150_ddl_guard_rwr.sh) (query 1, line 1) (in query: RENAME TABLE test_01150.t2 TO test_01150.t1, test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:115: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a016f6 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:21:18.398425 [ 46932 ] {} TCPHandler: Code: 81. DB::Exception: Database test_01150 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:115: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a016f6 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:21:19.214050 [ 46932 ] {e5f85406-baa1-45df-8584-a3517179ffed} executeQuery: Code: 57. DB::Exception: Table test_01150.t2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48976) (comment: 01150_ddl_guard_rwr.sh) (query 1, line 1) (in query: RENAME TABLE test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002e99856a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a098cf 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a015af 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:21:19.222620 [ 46932 ] {} TCPHandler: Code: 57. DB::Exception: Table test_01150.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002e99856a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a098cf 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a015af 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:21:19.976910 [ 46932 ] {6956573b-bab1-46a0-9c63-5cb6b9b33e6c} executeQuery: Code: 81. DB::Exception: Database test_01150 does not exist. (UNKNOWN_DATABASE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48992) (comment: 01150_ddl_guard_rwr.sh) (query 1, line 1) (in query: RENAME TABLE test_01150.t1 TO test_01150.t2_tmp, test_01150.t2 TO test_01150.t1, test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:115: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a016f6 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:21:19.986372 [ 46932 ] {} TCPHandler: Code: 81. DB::Exception: Database test_01150 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:115: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a016f6 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:21:20.809593 [ 46932 ] {21cedc5e-e0b6-487d-b60b-b473961e193e} executeQuery: Code: 57. DB::Exception: Table test_01150.t1 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49000) (comment: 01150_ddl_guard_rwr.sh) (query 1, line 1) (in query: RENAME TABLE test_01150.t2 TO test_01150.t1, test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002e99856a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a098cf 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a015af 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:21:20.819994 [ 46932 ] {} TCPHandler: Code: 57. DB::Exception: Table test_01150.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002e99856a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a098cf 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a015af 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:21:21.596149 [ 46932 ] {13689ca0-a5aa-4ef4-8908-7eff47a71ff4} executeQuery: Code: 81. DB::Exception: Database test_01150 does not exist. (UNKNOWN_DATABASE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49008) (comment: 01150_ddl_guard_rwr.sh) (query 1, line 1) (in query: RENAME TABLE test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:115: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a016f6 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:21:21.606014 [ 46932 ] {} TCPHandler: Code: 81. DB::Exception: Database test_01150 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:115: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a016f6 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:21:23.193477 [ 46928 ] {139eb093-b2a9-4405-a78e-77d915b01a9b} executeQuery: Code: 81. DB::Exception: Database test_01150 does not exist. (UNKNOWN_DATABASE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49782) (comment: 01150_ddl_guard_rwr.sh) (query 1, line 1) (in query: RENAME TABLE test_01150.t2 TO test_01150.t1, test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:115: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a016f6 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:21:23.202535 [ 46928 ] {} TCPHandler: Code: 81. DB::Exception: Database test_01150 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:115: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a016f6 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:21:23.996862 [ 46928 ] {552f3f89-ae8f-4056-9481-bae1b0191cf8} executeQuery: Code: 57. DB::Exception: Table test_01150.t2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49798) (comment: 01150_ddl_guard_rwr.sh) (query 1, line 1) (in query: RENAME TABLE test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002e99856a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a098cf 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a015af 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:21:24.005126 [ 46928 ] {} TCPHandler: Code: 57. DB::Exception: Table test_01150.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002e99856a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a098cf 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a015af 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:21:25.551741 [ 46932 ] {e37d24bc-d989-4e17-a0c4-4229a98dd49d} executeQuery: Code: 81. DB::Exception: Database test_01150 does not exist. (UNKNOWN_DATABASE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49822) (comment: 01150_ddl_guard_rwr.sh) (query 1, line 1) (in query: RENAME TABLE test_01150.t2 TO test_01150.t1, test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:115: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a016f6 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:21:25.560297 [ 46932 ] {} TCPHandler: Code: 81. DB::Exception: Database test_01150 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:115: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a016f6 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:21:26.361914 [ 46932 ] {693c72c3-c3a6-4c54-b73f-eb2130b729ee} executeQuery: Code: 57. DB::Exception: Table test_01150.t2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49836) (comment: 01150_ddl_guard_rwr.sh) (query 1, line 1) (in query: RENAME TABLE test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002e99856a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a098cf 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a015af 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:21:26.369081 [ 46932 ] {} TCPHandler: Code: 57. DB::Exception: Table test_01150.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002e99856a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a098cf 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032a015af 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000329fcebd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:21:56.550386 [ 53323 ] {b7f87cf3-eb2e-4f48-adb9-e4c7f34bdd73} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43076) (comment: 01079_parallel_alter_modify_zookeeper_long.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_mt_1 MODIFY COLUMN value1 UInt32 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:21:56.550454 [ 53320 ] {3dc64a92-619c-42bf-bcdf-c016a29c4320} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43058) (comment: 01079_parallel_alter_modify_zookeeper_long.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_mt_4 MODIFY COLUMN value1 UInt32 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:21:56.562541 [ 53320 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:21:56.571494 [ 53323 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:21:58.227105 [ 53316 ] {111fcb88-54d8-4c14-b64d-e0676dfac59f} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43218) (comment: 01079_parallel_alter_modify_zookeeper_long.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_mt_5 MODIFY COLUMN value1 UInt32 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:21:58.247417 [ 53316 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:21:58.737641 [ 53310 ] {d21021ae-55cc-47be-8694-876facdfb10d} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43224) (comment: 01079_parallel_alter_modify_zookeeper_long.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_mt_5 MODIFY COLUMN value1 UInt8 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:21:58.777138 [ 53310 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:21:59.207030 [ 53326 ] {09ea6f51-aae8-4990-b092-f953b8502d84} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43274) (comment: 01079_parallel_alter_modify_zookeeper_long.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_mt_1 MODIFY COLUMN value1 UInt8 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:21:59.227758 [ 53326 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:22:00.422234 [ 53322 ] {4cb8a8da-56d4-4c41-b8a0-005061db04f9} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43368) (comment: 01079_parallel_alter_modify_zookeeper_long.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_mt_3 MODIFY COLUMN value1 Float64 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:22:00.434357 [ 53391 ] {af324f5c-82ff-4fa8-b1ae-1e18402368d4} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43414) (comment: 01079_parallel_alter_modify_zookeeper_long.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_mt_5 MODIFY COLUMN value1 UInt8 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:22:00.443256 [ 53322 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:22:00.464093 [ 53391 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:22:01.697590 [ 53323 ] {6c6e27c7-d348-4093-b259-0dec38fadd0b} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43456) (comment: 01079_parallel_alter_modify_zookeeper_long.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_mt_5 MODIFY COLUMN value1 UInt32 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:22:01.720472 [ 53323 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:22:01.937365 [ 53320 ] {5f99938a-1069-43db-820b-33e960dc3f98} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43486) (comment: 01079_parallel_alter_modify_zookeeper_long.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_mt_5 MODIFY COLUMN value1 UInt8 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:22:01.960833 [ 53320 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:22:02.039188 [ 53316 ] {0cb53388-ebe2-497b-a421-e5dd78026878} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43516) (comment: 01079_parallel_alter_modify_zookeeper_long.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_mt_2 MODIFY COLUMN value1 Float64 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:22:02.064999 [ 53316 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:22:03.037836 [ 53391 ] {35e0a3c8-8938-4c56-8fc9-06606a3e810f} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43576) (comment: 01079_parallel_alter_modify_zookeeper_long.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_mt_5 MODIFY COLUMN value1 UInt8 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:22:03.071689 [ 53391 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:22:03.925522 [ 1029 ] {8bb62200-4a98-4791-b8ba-9f492e4ac821::all_0_35_2_22} 8bb62200-4a98-4791-b8ba-9f492e4ac821::all_0_35_2_22 (MergeFromLogEntryTask): Code: 40. DB::Exception: Part all_0_35_2_22 from 4 has different columns hash (it may rarely happen on race condition with KILL MUTATION). (CHECKSUM_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)). Data after merge is not byte-identical to data on another replicas. There could be several reasons: 1. Using newer version of compression library after server update. 2. Using another compression method. 3. Non-deterministic compression algorithm (highly unlikely). 4. Non-deterministic merge algorithm due to logical error in code. 5. Data corruption in memory due to bug in code. 6. Data corruption in memory due to hardware issue. 7. Manual modification of source data after server startup. 8. Manual modification of checksums stored in ZooKeeper. 9. Part format related settings like 'enable_mixed_granularity_parts' are different on different replicas. We will download merged part from replica to force byte-identical result. List of files in local parts: count.txt: 2 (31c9265d490fc91e1bda7147b29edec6) data.bin: 934 (0fac24dd3175d4850f527c32aed8bca3) data.cmrk3: 72 (8789b46b17547dc8fba1364cbcb25c50) primary.cidx: 50 (d5e1b9199c82deee0f2bab22d71b875f) 2025.06.13 09:22:03.985190 [ 53320 ] {b1605327-2a1d-4d2b-b73f-f66c860ba697} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41622) (comment: 01079_parallel_alter_modify_zookeeper_long.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_mt_1 MODIFY COLUMN value1 String SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:22:04.006776 [ 53320 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:22:04.562314 [ 53310 ] {b7e665b5-a014-4d0f-b928-a6452d9bc8ac} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41698) (comment: 01079_parallel_alter_modify_zookeeper_long.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_mt_5 MODIFY COLUMN value1 UInt8 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:22:04.589601 [ 53310 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:22:05.602015 [ 53323 ] {7fe84b83-980f-4eea-bf2b-df39dcbb2910} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41792) (comment: 01079_parallel_alter_modify_zookeeper_long.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_mt_4 MODIFY COLUMN value1 UInt32 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:22:05.637156 [ 53323 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:22:05.640725 [ 53322 ] {6bce5429-6cf6-4f6f-b20b-710a2dc91788} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41788) (comment: 01079_parallel_alter_modify_zookeeper_long.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_mt_1 MODIFY COLUMN value1 String SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:22:05.673589 [ 53322 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:22:07.042516 [ 53388 ] {977778d5-c546-4229-89a4-a6cddc59a59c} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41890) (comment: 01079_parallel_alter_modify_zookeeper_long.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_mt_1 MODIFY COLUMN value1 Float64 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:22:07.061546 [ 53388 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:22:07.223928 [ 53316 ] {b40db749-7520-4856-af78-1796ef296be4} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41926) (comment: 01079_parallel_alter_modify_zookeeper_long.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_mt_2 MODIFY COLUMN value1 UInt32 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:22:07.248673 [ 53316 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:22:08.817933 [ 53825 ] {0b75d107-c2d9-43dc-9738-98033d46ec8c} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42102) (comment: 01079_parallel_alter_modify_zookeeper_long.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_mt_1 MODIFY COLUMN value1 String SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:22:08.849393 [ 53825 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:22:09.259743 [ 53320 ] {f7fb4c76-c52a-43ed-b70a-46034f7f75f1} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42126) (comment: 01079_parallel_alter_modify_zookeeper_long.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_mt_1 MODIFY COLUMN value1 Float64 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:22:09.279223 [ 53320 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:22:10.192331 [ 53320 ] {0b902e53-d2c9-4fcc-a580-e67bf58492f3} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42236) (comment: 01079_parallel_alter_modify_zookeeper_long.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_mt_2 MODIFY COLUMN value1 UInt32 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:22:10.219973 [ 53320 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:22:10.313350 [ 53316 ] {18a4e84d-1bec-4dbd-be8c-bf771a320c2a} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42232) (comment: 01079_parallel_alter_modify_zookeeper_long.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_mt_5 MODIFY COLUMN value1 Float64 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:22:10.343613 [ 53316 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:22:10.719000 [ 53320 ] {f341e4e3-ee97-433f-8b1c-e7f422328ba9} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42268) (comment: 01079_parallel_alter_modify_zookeeper_long.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_mt_3 MODIFY COLUMN value1 UInt32 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:22:10.738459 [ 53320 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:22:12.163545 [ 53323 ] {d6e1544e-f4b2-408e-80c5-7baaf76735cb} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42392) (comment: 01079_parallel_alter_modify_zookeeper_long.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_mt_1 MODIFY COLUMN value1 UInt32 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:22:12.188755 [ 53323 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:22:12.676249 [ 53310 ] {4511f431-6410-4f8c-9168-d3d6971b028e} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42438) (comment: 01079_parallel_alter_modify_zookeeper_long.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_mt_1 MODIFY COLUMN value1 UInt8 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:22:12.717791 [ 53310 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:22:13.346500 [ 53316 ] {78252c00-a85c-4919-9a19-257f27be3b7e} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42484) (comment: 01079_parallel_alter_modify_zookeeper_long.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_mt_2 MODIFY COLUMN value1 UInt32 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:22:13.371910 [ 53316 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:22:14.526549 [ 53320 ] {19e4be9f-40b8-4ecf-aa57-01b975dd7009} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57368) (comment: 01079_parallel_alter_modify_zookeeper_long.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_mt_4 MODIFY COLUMN value1 Float64 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:22:14.553642 [ 53320 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:22:14.821383 [ 53388 ] {a6509947-b500-4f58-a180-76f00ddb1d36} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57392) (comment: 01079_parallel_alter_modify_zookeeper_long.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_mt_1 MODIFY COLUMN value1 UInt32 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:22:14.835681 [ 53388 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:22:15.320011 [ 53322 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:57448, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fbc2c6f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fbc3c01 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9b2eba 6. DB::ReadBuffer::next() @ 0x0000000008e83ccf 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003ad8c853 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:22:15.321277 [ 53322 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:57448, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fbc2c6f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fbc3c01 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9b2eba 6. DB::ReadBuffer::next() @ 0x0000000008e83ccf 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003ad8c853 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:22:15.416741 [ 53384 ] {a7ea974a-ed71-446a-984d-263723009159} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:57462, local: [::1]:9000). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57462) (comment: 01079_parallel_alter_modify_zookeeper_long.sh) (query 1, line 1) (in query: INSERT INTO concurrent_alter_mt_4 VALUES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fbc2c6f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fbc3c01 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9b2eba 6. ./src/IO/ReadBuffer.h:60: DB::TCPHandler::receivePacketsExpectData(DB::QueryState&) @ 0x000000003add745f 7. ./build_docker/./src/Server/TCPHandler.cpp:932: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003adbbbd5 8. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x000000003ad8e9f8 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:22:15.429817 [ 53384 ] {a7ea974a-ed71-446a-984d-263723009159} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:57462). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2531: DB::TCPHandler::sendLogData(DB::QueryState&, DB::Block const&) @ 0x000000003adf5ea1 7. ./build_docker/./src/Server/TCPHandler.cpp:2619: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x000000003adbfa58 8. ./build_docker/./src/Server/TCPHandler.cpp:820: DB::TCPHandler::runImpl() @ 0x000000003ad8f4a9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:22:15.437010 [ 53384 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:57462, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fbc2c6f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fbc3c01 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9b2eba 6. ./src/IO/ReadBuffer.h:60: DB::TCPHandler::receivePacketsExpectData(DB::QueryState&) @ 0x000000003add745f 7. ./build_docker/./src/Server/TCPHandler.cpp:932: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003adbbbd5 8. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x000000003ad8e9f8 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:22:15.468435 [ 53310 ] {12232b90-4878-4d08-8c0c-874e19a91f3b} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:57410). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57410) (comment: 01079_parallel_alter_modify_zookeeper_long.sh) (query 1, line 1) (in query: INSERT INTO concurrent_alter_mt_4 VALUES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2569: DB::TCPHandler::runImpl() @ 0x000000003ad8ebbd 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 2025.06.13 09:22:15.468561 [ 53830 ] {f98d5c4e-4466-40a5-b78f-4af2366d7340} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:57434). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57434) (comment: 01079_parallel_alter_modify_zookeeper_long.sh) (query 1, line 1) (in query: INSERT INTO concurrent_alter_mt_3 VALUES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2569: DB::TCPHandler::runImpl() @ 0x000000003ad8ebbd 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 2025.06.13 09:22:15.478422 [ 53830 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:57434). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2569: DB::TCPHandler::runImpl() @ 0x000000003ad8ebbd 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 2025.06.13 09:22:15.478422 [ 53310 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:57410). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2569: DB::TCPHandler::runImpl() @ 0x000000003ad8ebbd 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 2025.06.13 09:22:15.529939 [ 46928 ] {} void DB::TCPHandler::runImpl(): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:57474). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2557: DB::TCPHandler::sendException(DB::Exception const&, bool) @ 0x000000003adb5f67 7. ./build_docker/./src/Server/TCPHandler.cpp:422: DB::TCPHandler::runImpl() @ 0x000000003ad975c5 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:22:15.531153 [ 46928 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:57474, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fbc2c6f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fbc3c01 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9b2eba 6. DB::ReadBuffer::next() @ 0x0000000008e83ccf 7. ./src/IO/ReadBuffer.h:96: DB::readStringBinary(String&, DB::ReadBuffer&, unsigned long) @ 0x000000001f8e886c 8. ./build_docker/./src/Server/TCPHandler.cpp:1804: DB::TCPHandler::receiveAddendum() @ 0x000000003adb48b3 9. ./build_docker/./src/Server/TCPHandler.cpp:350: DB::TCPHandler::runImpl() @ 0x000000003ad8b1dd 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:22:15.532006 [ 46928 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:57474, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fbc2c6f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fbc3c01 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9b2eba 6. DB::ReadBuffer::next() @ 0x0000000008e83ccf 7. ./src/IO/ReadBuffer.h:96: DB::readStringBinary(String&, DB::ReadBuffer&, unsigned long) @ 0x000000001f8e886c 8. ./build_docker/./src/Server/TCPHandler.cpp:1804: DB::TCPHandler::receiveAddendum() @ 0x000000003adb48b3 9. ./build_docker/./src/Server/TCPHandler.cpp:350: DB::TCPHandler::runImpl() @ 0x000000003ad8b1dd 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:22:16.019765 [ 1019 ] {b96576b8-7909-44e2-a3fe-a6edddf3455e::all_103_141_3_125} b96576b8-7909-44e2-a3fe-a6edddf3455e::all_103_141_3_125 (MergeFromLogEntryTask): Code: 40. DB::Exception: Part all_103_141_3_125 from 4 has different columns hash (it may rarely happen on race condition with KILL MUTATION). (CHECKSUM_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)). Data after merge is not byte-identical to data on another replicas. There could be several reasons: 1. Using newer version of compression library after server update. 2. Using another compression method. 3. Non-deterministic compression algorithm (highly unlikely). 4. Non-deterministic merge algorithm due to logical error in code. 5. Data corruption in memory due to bug in code. 6. Data corruption in memory due to hardware issue. 7. Manual modification of source data after server startup. 8. Manual modification of checksums stored in ZooKeeper. 9. Part format related settings like 'enable_mixed_granularity_parts' are different on different replicas. We will download merged part from replica to force byte-identical result. List of files in local parts: count.txt: 2 (f7bf1d511906fe386f5a7b1dc8c71617) data.bin: 503 (b06f4ec55242e4b67e9f9b574382ed0b) data.cmrk3: 72 (5ed62e1ca5126175f657b2db5b375cea) primary.cidx: 50 (eb1893a252654e16efbe1bcf0e14e426) 2025.06.13 09:22:16.152448 [ 1022 ] {b96576b8-7909-44e2-a3fe-a6edddf3455e::all_143_150_1} b96576b8-7909-44e2-a3fe-a6edddf3455e::all_143_150_1 (MergeFromLogEntryTask): Code: 40. DB::Exception: Part all_143_150_1 from 3 has different columns hash (it may rarely happen on race condition with KILL MUTATION). (CHECKSUM_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)). Data after merge is not byte-identical to data on another replicas. There could be several reasons: 1. Using newer version of compression library after server update. 2. Using another compression method. 3. Non-deterministic compression algorithm (highly unlikely). 4. Non-deterministic merge algorithm due to logical error in code. 5. Data corruption in memory due to bug in code. 6. Data corruption in memory due to hardware issue. 7. Manual modification of source data after server startup. 8. Manual modification of checksums stored in ZooKeeper. 9. Part format related settings like 'enable_mixed_granularity_parts' are different on different replicas. We will download merged part from replica to force byte-identical result. List of files in local parts: count.txt: 1 (68a022a0706306b542babba12dcd25a6) data.bin: 278 (3a49ecd6dd22f2c5a22332781d4c477d) data.cmrk3: 71 (4b011a103fd02db6c103a979194b7f2d) primary.cidx: 50 (23425c2d6f4bbff883a32f850859625e) 2025.06.13 09:22:16.152644 [ 1023 ] {f72a140f-db28-4256-bb56-ce5584b6163f::all_143_150_1} f72a140f-db28-4256-bb56-ce5584b6163f::all_143_150_1 (MergeFromLogEntryTask): Code: 40. DB::Exception: Part all_143_150_1 from 3 has different columns hash (it may rarely happen on race condition with KILL MUTATION). (CHECKSUM_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)). Data after merge is not byte-identical to data on another replicas. There could be several reasons: 1. Using newer version of compression library after server update. 2. Using another compression method. 3. Non-deterministic compression algorithm (highly unlikely). 4. Non-deterministic merge algorithm due to logical error in code. 5. Data corruption in memory due to bug in code. 6. Data corruption in memory due to hardware issue. 7. Manual modification of source data after server startup. 8. Manual modification of checksums stored in ZooKeeper. 9. Part format related settings like 'enable_mixed_granularity_parts' are different on different replicas. We will download merged part from replica to force byte-identical result. List of files in local parts: count.txt: 1 (68a022a0706306b542babba12dcd25a6) data.bin: 278 (3a49ecd6dd22f2c5a22332781d4c477d) data.cmrk3: 71 (4b011a103fd02db6c103a979194b7f2d) primary.cidx: 50 (23425c2d6f4bbff883a32f850859625e) 2025.06.13 09:22:16.220010 [ 1028 ] {8bb62200-4a98-4791-b8ba-9f492e4ac821::all_143_150_1} 8bb62200-4a98-4791-b8ba-9f492e4ac821::all_143_150_1 (MergeFromLogEntryTask): Code: 40. DB::Exception: Part all_143_150_1 from 3 has different columns hash (it may rarely happen on race condition with KILL MUTATION). (CHECKSUM_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)). Data after merge is not byte-identical to data on another replicas. There could be several reasons: 1. Using newer version of compression library after server update. 2. Using another compression method. 3. Non-deterministic compression algorithm (highly unlikely). 4. Non-deterministic merge algorithm due to logical error in code. 5. Data corruption in memory due to bug in code. 6. Data corruption in memory due to hardware issue. 7. Manual modification of source data after server startup. 8. Manual modification of checksums stored in ZooKeeper. 9. Part format related settings like 'enable_mixed_granularity_parts' are different on different replicas. We will download merged part from replica to force byte-identical result. List of files in local parts: count.txt: 1 (68a022a0706306b542babba12dcd25a6) data.bin: 278 (3a49ecd6dd22f2c5a22332781d4c477d) data.cmrk3: 71 (4b011a103fd02db6c103a979194b7f2d) primary.cidx: 50 (23425c2d6f4bbff883a32f850859625e) 2025.06.13 09:23:24.587332 [ 53391 ] {1a1df236-1d1b-48c8-b9fb-386fededbb03} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51486) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_1 ADD COLUMN value2 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:23:24.600750 [ 53391 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:23:24.715504 [ 53310 ] {798fe7c0-e662-428e-ba9e-7611197b9338} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51490) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_2 ADD COLUMN value1 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:23:24.730305 [ 53310 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:23:25.432548 [ 53388 ] {522255e2-3381-4b25-b357-96e0c1cf37e7} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value5` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51514) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_2 DROP COLUMN value5 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819bfb7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:23:25.448973 [ 53388 ] {} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value5` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819bfb7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:23:25.571531 [ 53326 ] {97b75f74-8a2b-4946-8a7c-dd184d5ae46c} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value5` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51568) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_2 DROP COLUMN value5 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819bfb7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:23:25.585734 [ 53326 ] {} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value5` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819bfb7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:23:26.777018 [ 53314 ] {5ac3741d-1672-4f13-a39f-328c99066d48} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51658) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_1 ADD COLUMN value5 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:23:26.793522 [ 53314 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:23:26.929275 [ 53391 ] {740b742e-fdf8-4a15-bdde-792c4461ef29} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51664) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_1 ADD COLUMN value3 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:23:26.942880 [ 53391 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:23:27.530084 [ 53388 ] {f2fdd4f9-aa3b-4b8e-a3c2-329d9b4e2327} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value3` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51692) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_3 DROP COLUMN value3 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819bfb7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:23:27.547122 [ 53388 ] {} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value3` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819bfb7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:23:27.850510 [ 53314 ] {b6aa0a10-7f31-48ff-a3f7-bffd5980903f} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value3` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51728) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_1 DROP COLUMN value3 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819bfb7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:23:27.866355 [ 53314 ] {} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value3` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819bfb7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:23:29.289403 [ 53391 ] {93356a12-e333-4cfb-a2b4-9651369945d0} executeQuery: Code: 15. DB::Exception: Cannot add column `value3`: column with this name already exists. (DUPLICATE_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51820) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_2 ADD COLUMN value3 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819958a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:23:29.306448 [ 53391 ] {} TCPHandler: Code: 15. DB::Exception: Cannot add column `value3`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819958a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:23:29.765989 [ 53830 ] {c41ded66-1f6e-4432-9c69-d2e42e634d31} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value5` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51884) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_3 DROP COLUMN value5 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819bfb7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:23:29.779786 [ 53830 ] {} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value5` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819bfb7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:23:30.185268 [ 53391 ] {af7390dc-b561-421b-a553-27a338d3f2b9} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value1` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51916) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_2 DROP COLUMN value1 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819bfb7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:23:30.201120 [ 53391 ] {} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value1` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819bfb7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:23:30.787609 [ 53314 ] {f63823f8-a27b-4a8f-b8cc-d1175a663318} executeQuery: Code: 15. DB::Exception: Cannot add column `value3`: column with this name already exists. (DUPLICATE_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51984) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_1 ADD COLUMN value3 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819958a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:23:30.800134 [ 53314 ] {} TCPHandler: Code: 15. DB::Exception: Cannot add column `value3`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819958a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:23:31.655850 [ 53825 ] {f2ed8dcc-a7bd-4268-97bb-33f1d6a2b82d} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value4` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52042) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_1 DROP COLUMN value4 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819bfb7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:23:31.667837 [ 53825 ] {} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value4` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819bfb7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:23:31.883923 [ 1029 ] {29835c18-4bb4-45f2-9d19-18a693335809::all_0_15_17_16} 29835c18-4bb4-45f2-9d19-18a693335809::all_0_15_17_16 (MergeFromLogEntryTask): Code: 40. DB::Exception: Part all_0_15_17_16 from 2 has different columns hash (it may rarely happen on race condition with KILL MUTATION). (CHECKSUM_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)). Data after merge is not byte-identical to data on another replicas. There could be several reasons: 1. Using newer version of compression library after server update. 2. Using another compression method. 3. Non-deterministic compression algorithm (highly unlikely). 4. Non-deterministic merge algorithm due to logical error in code. 5. Data corruption in memory due to bug in code. 6. Data corruption in memory due to hardware issue. 7. Manual modification of source data after server startup. 8. Manual modification of checksums stored in ZooKeeper. 9. Part format related settings like 'enable_mixed_granularity_parts' are different on different replicas. We will download merged part from replica to force byte-identical result. List of files in local parts: count.txt: 6 (216cf31cbc4ff1114d0d609d7899ac94) data.bin: 412719 (ba83d961ffeea7197da9471b68a22363) data.cmrk3: 268 (0681884c7f3128e201e34c433c241a38) primary.cidx: 100 (3b963fea6137d74164b158ecddaff666) serialization.json: 383 (5c47766bdee8311cb7684d0e837888be) 2025.06.13 09:23:32.481958 [ 53314 ] {9acdd4aa-2a57-43b0-94d2-e4c498757233} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52108) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_3 DROP COLUMN value3 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:23:32.500121 [ 53314 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:23:33.211819 [ 1026 ] {29835c18-4bb4-45f2-9d19-18a693335809::all_0_15_20_16} 29835c18-4bb4-45f2-9d19-18a693335809::all_0_15_20_16 (MergeFromLogEntryTask): Code: 40. DB::Exception: Part all_0_15_20_16 from 2 has different columns hash (it may rarely happen on race condition with KILL MUTATION). (CHECKSUM_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)). Data after merge is not byte-identical to data on another replicas. There could be several reasons: 1. Using newer version of compression library after server update. 2. Using another compression method. 3. Non-deterministic compression algorithm (highly unlikely). 4. Non-deterministic merge algorithm due to logical error in code. 5. Data corruption in memory due to bug in code. 6. Data corruption in memory due to hardware issue. 7. Manual modification of source data after server startup. 8. Manual modification of checksums stored in ZooKeeper. 9. Part format related settings like 'enable_mixed_granularity_parts' are different on different replicas. We will download merged part from replica to force byte-identical result. List of files in local parts: count.txt: 6 (216cf31cbc4ff1114d0d609d7899ac94) data.bin: 414750 (3d8f595cbdf80bfc4ccf9b4989a76b6c) data.cmrk3: 307 (af73ff3f6b7b3b6e4faad20d513404a2) primary.cidx: 100 (3b963fea6137d74164b158ecddaff666) serialization.json: 453 (407e83e646ba5378401ccd68c7c6bc70) 2025.06.13 09:23:33.653670 [ 53314 ] {66731b9b-da58-4d19-b60f-6582ec6041e3} executeQuery: Code: 15. DB::Exception: Cannot add column `value2`: column with this name already exists. (DUPLICATE_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51776) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_2 ADD COLUMN value2 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819958a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:23:33.666402 [ 53314 ] {} TCPHandler: Code: 15. DB::Exception: Cannot add column `value2`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819958a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:23:33.812442 [ 53825 ] {c55babce-e155-4142-aa61-bf9096017b36} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value3` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51788) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_2 DROP COLUMN value3 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819bfb7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:23:33.823167 [ 53825 ] {} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value3` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819bfb7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:23:34.522748 [ 53825 ] {dd28ed65-0fe2-41f6-adc9-68a25585584c} executeQuery: Code: 15. DB::Exception: Cannot add column `value1`: column with this name already exists. (DUPLICATE_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51860) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_1 ADD COLUMN value1 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819958a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:23:34.534746 [ 53825 ] {} TCPHandler: Code: 15. DB::Exception: Cannot add column `value1`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819958a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:23:35.376124 [ 53310 ] {8724e031-43a8-414a-a250-16356f617f7a} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value1` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51926) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_1 DROP COLUMN value1 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819bfb7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:23:35.401492 [ 53310 ] {} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value1` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819bfb7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:23:35.621505 [ 1029 ] {0ebe1f6d-b6dc-4825-94b7-da5ac6abd6c1::all_0_15_25_19} 0ebe1f6d-b6dc-4825-94b7-da5ac6abd6c1::all_0_15_25_19 (MergeFromLogEntryTask): Code: 40. DB::Exception: Part all_0_15_25_19 from 3 has different columns hash (it may rarely happen on race condition with KILL MUTATION). (CHECKSUM_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)). Data after merge is not byte-identical to data on another replicas. There could be several reasons: 1. Using newer version of compression library after server update. 2. Using another compression method. 3. Non-deterministic compression algorithm (highly unlikely). 4. Non-deterministic merge algorithm due to logical error in code. 5. Data corruption in memory due to bug in code. 6. Data corruption in memory due to hardware issue. 7. Manual modification of source data after server startup. 8. Manual modification of checksums stored in ZooKeeper. 9. Part format related settings like 'enable_mixed_granularity_parts' are different on different replicas. We will download merged part from replica to force byte-identical result. List of files in local parts: count.txt: 6 (216cf31cbc4ff1114d0d609d7899ac94) data.bin: 414750 (3d8f595cbdf80bfc4ccf9b4989a76b6c) data.cmrk3: 307 (af73ff3f6b7b3b6e4faad20d513404a2) primary.cidx: 100 (3b963fea6137d74164b158ecddaff666) serialization.json: 453 (3d6e084397d9d4baee5316c3051c9a86) 2025.06.13 09:23:36.404679 [ 53326 ] {eb4fd57e-7456-4f19-82ac-815dc22884e6} executeQuery: Code: 15. DB::Exception: Cannot add column `value5`: column with this name already exists. (DUPLICATE_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52020) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_1 ADD COLUMN value5 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819958a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:23:36.420349 [ 53326 ] {} TCPHandler: Code: 15. DB::Exception: Cannot add column `value5`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819958a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:23:37.280349 [ 53323 ] {3ad62422-91a6-47a0-b2c8-1cd94e0ff972} executeQuery: Code: 15. DB::Exception: Cannot add column `value2`: column with this name already exists. (DUPLICATE_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52090) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_1 ADD COLUMN value2 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819958a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:23:37.297287 [ 53323 ] {} TCPHandler: Code: 15. DB::Exception: Cannot add column `value2`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819958a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:23:37.617167 [ 1022 ] {0ebe1f6d-b6dc-4825-94b7-da5ac6abd6c1::all_0_15_29_20} 0ebe1f6d-b6dc-4825-94b7-da5ac6abd6c1::all_0_15_29_20 (MergeFromLogEntryTask): Code: 40. DB::Exception: Part all_0_15_29_20 from 1 has different columns hash (it may rarely happen on race condition with KILL MUTATION). (CHECKSUM_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)). Data after merge is not byte-identical to data on another replicas. There could be several reasons: 1. Using newer version of compression library after server update. 2. Using another compression method. 3. Non-deterministic compression algorithm (highly unlikely). 4. Non-deterministic merge algorithm due to logical error in code. 5. Data corruption in memory due to bug in code. 6. Data corruption in memory due to hardware issue. 7. Manual modification of source data after server startup. 8. Manual modification of checksums stored in ZooKeeper. 9. Part format related settings like 'enable_mixed_granularity_parts' are different on different replicas. We will download merged part from replica to force byte-identical result. List of files in local parts: count.txt: 6 (216cf31cbc4ff1114d0d609d7899ac94) data.bin: 414750 (3d8f595cbdf80bfc4ccf9b4989a76b6c) data.cmrk3: 307 (af73ff3f6b7b3b6e4faad20d513404a2) primary.cidx: 100 (3b963fea6137d74164b158ecddaff666) serialization.json: 453 (3d6e084397d9d4baee5316c3051c9a86) 2025.06.13 09:23:38.158876 [ 53830 ] {193857c4-3703-468f-9afe-182a5b3ad271} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value2` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52168) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_1 DROP COLUMN value2 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819bfb7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:23:38.177679 [ 53830 ] {} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value2` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819bfb7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:23:39.196525 [ 53825 ] {ad500db6-0578-4dc2-9596-4241d3792517} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52216) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_2 ADD COLUMN value2 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:23:39.211322 [ 53825 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:23:39.336128 [ 1014 ] {0ebe1f6d-b6dc-4825-94b7-da5ac6abd6c1::all_0_15_31_22} 0ebe1f6d-b6dc-4825-94b7-da5ac6abd6c1::all_0_15_31_22 (MergeFromLogEntryTask): Code: 40. DB::Exception: Part all_0_15_31_22 from 1 has different columns hash (it may rarely happen on race condition with KILL MUTATION). (CHECKSUM_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)). Data after merge is not byte-identical to data on another replicas. There could be several reasons: 1. Using newer version of compression library after server update. 2. Using another compression method. 3. Non-deterministic compression algorithm (highly unlikely). 4. Non-deterministic merge algorithm due to logical error in code. 5. Data corruption in memory due to bug in code. 6. Data corruption in memory due to hardware issue. 7. Manual modification of source data after server startup. 8. Manual modification of checksums stored in ZooKeeper. 9. Part format related settings like 'enable_mixed_granularity_parts' are different on different replicas. We will download merged part from replica to force byte-identical result. List of files in local parts: count.txt: 6 (216cf31cbc4ff1114d0d609d7899ac94) data.bin: 410688 (0b2fb6447b30c2cbe4317e7f2e654674) data.cmrk3: 265 (610d3b149fc26c2596abc548e6331826) primary.cidx: 100 (3b963fea6137d74164b158ecddaff666) serialization.json: 313 (b97756d9de0c6ac287215e8b353fecc6) 2025.06.13 09:23:39.476944 [ 53310 ] {2d32d1b0-b5b3-4d59-8a33-a8776f85ece4} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value3` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52266) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_1 DROP COLUMN value3 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819bfb7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:23:39.488343 [ 53310 ] {} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value3` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819bfb7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:23:39.539079 [ 53388 ] {6b213736-7d6f-43c6-b4f2-41c2f203398c} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52248) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_3 ADD COLUMN value4 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:23:39.555115 [ 53388 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:23:39.642887 [ 1016 ] {b20d0a19-983f-4726-9a88-09c3cff29dd6::all_0_15_31_22} b20d0a19-983f-4726-9a88-09c3cff29dd6::all_0_15_31_22 (MergeFromLogEntryTask): Code: 40. DB::Exception: Part all_0_15_31_22 from 1 has different columns hash (it may rarely happen on race condition with KILL MUTATION). (CHECKSUM_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)). Data after merge is not byte-identical to data on another replicas. There could be several reasons: 1. Using newer version of compression library after server update. 2. Using another compression method. 3. Non-deterministic compression algorithm (highly unlikely). 4. Non-deterministic merge algorithm due to logical error in code. 5. Data corruption in memory due to bug in code. 6. Data corruption in memory due to hardware issue. 7. Manual modification of source data after server startup. 8. Manual modification of checksums stored in ZooKeeper. 9. Part format related settings like 'enable_mixed_granularity_parts' are different on different replicas. We will download merged part from replica to force byte-identical result. List of files in local parts: count.txt: 6 (216cf31cbc4ff1114d0d609d7899ac94) data.bin: 410688 (0b2fb6447b30c2cbe4317e7f2e654674) data.cmrk3: 265 (610d3b149fc26c2596abc548e6331826) primary.cidx: 100 (3b963fea6137d74164b158ecddaff666) serialization.json: 313 (b97756d9de0c6ac287215e8b353fecc6) 2025.06.13 09:23:40.524158 [ 53310 ] {d51d625a-33eb-479e-bfa8-ef675c77a713} executeQuery: Code: 15. DB::Exception: Cannot add column `value5`: column with this name already exists. (DUPLICATE_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52358) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_1 ADD COLUMN value5 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819958a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:23:40.537427 [ 53310 ] {} TCPHandler: Code: 15. DB::Exception: Cannot add column `value5`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819958a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:23:40.577296 [ 53388 ] {12b3594c-879a-4557-ab41-3d31d10115a9} executeQuery: Code: 36. DB::Exception: Cannot drop column value2 because it's affected by mutation with ID '0000000008' which is not finished yet. Wait this mutation, or KILL it with command "KILL MUTATION WHERE mutation_id = '0000000008'". (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52316) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_3 DROP COLUMN value2 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::MergeTreeData::checkDropCommandDoesntAffectInProgressMutations(DB::AlterCommand const&, std::map, std::allocator>> const&, std::shared_ptr) const::$_0::operator()(String const&, String const&, String const&) const @ 0x000000003993c58b 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8604: DB::MergeTreeData::checkDropCommandDoesntAffectInProgressMutations(DB::AlterCommand const&, std::map, std::allocator>> const&, std::shared_ptr) const @ 0x000000003982c3e9 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3638: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003981bc22 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:23:40.589331 [ 53388 ] {} TCPHandler: Code: 36. DB::Exception: Cannot drop column value2 because it's affected by mutation with ID '0000000008' which is not finished yet. Wait this mutation, or KILL it with command "KILL MUTATION WHERE mutation_id = '0000000008'". (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::MergeTreeData::checkDropCommandDoesntAffectInProgressMutations(DB::AlterCommand const&, std::map, std::allocator>> const&, std::shared_ptr) const::$_0::operator()(String const&, String const&, String const&) const @ 0x000000003993c58b 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8604: DB::MergeTreeData::checkDropCommandDoesntAffectInProgressMutations(DB::AlterCommand const&, std::map, std::allocator>> const&, std::shared_ptr) const @ 0x000000003982c3e9 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3638: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003981bc22 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894d07 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:23:40.657586 [ 1024 ] {b20d0a19-983f-4726-9a88-09c3cff29dd6::all_0_15_34_22} b20d0a19-983f-4726-9a88-09c3cff29dd6::all_0_15_34_22 (MergeFromLogEntryTask): Code: 40. DB::Exception: Part all_0_15_34_22 from 1 has different columns hash (it may rarely happen on race condition with KILL MUTATION). (CHECKSUM_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)). Data after merge is not byte-identical to data on another replicas. There could be several reasons: 1. Using newer version of compression library after server update. 2. Using another compression method. 3. Non-deterministic compression algorithm (highly unlikely). 4. Non-deterministic merge algorithm due to logical error in code. 5. Data corruption in memory due to bug in code. 6. Data corruption in memory due to hardware issue. 7. Manual modification of source data after server startup. 8. Manual modification of checksums stored in ZooKeeper. 9. Part format related settings like 'enable_mixed_granularity_parts' are different on different replicas. We will download merged part from replica to force byte-identical result. List of files in local parts: count.txt: 6 (216cf31cbc4ff1114d0d609d7899ac94) data.bin: 410688 (0b2fb6447b30c2cbe4317e7f2e654674) data.cmrk3: 265 (610d3b149fc26c2596abc548e6331826) primary.cidx: 100 (3b963fea6137d74164b158ecddaff666) serialization.json: 313 (b97756d9de0c6ac287215e8b353fecc6) 2025.06.13 09:23:41.374423 [ 53323 ] {80fe984c-674d-470e-9dfb-986ba11f2a92} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value3` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52408) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_1 DROP COLUMN value3 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819bfb7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:23:41.385409 [ 53323 ] {} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value3` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819bfb7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:23:42.288221 [ 53388 ] {3dd0cca0-0e4c-4860-8543-7cb16a5b97f8} executeQuery: Code: 15. DB::Exception: Cannot add column `value1`: column with this name already exists. (DUPLICATE_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52484) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_1 ADD COLUMN value1 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819958a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:23:42.300729 [ 53388 ] {} TCPHandler: Code: 15. DB::Exception: Cannot add column `value1`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819958a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:23:42.369825 [ 53391 ] {bc2eb516-3fbe-4f74-b495-5a0a45a2961b} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value2` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52490) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_2 DROP COLUMN value2 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819bfb7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:23:42.381318 [ 53391 ] {} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value2` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003819bfb7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894c42 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:23:43.567447 [ 53323 ] {69a83f94-6ebb-4b0f-9bc9-47c7b0b597f1} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36676) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_1 ADD COLUMN value2 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:23:43.582197 [ 53323 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6690: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000038a0b321 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032894dc1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:23:43.847817 [ 53308 ] {e5bbc634-3a05-4c4d-b727-cde96e6f8e82} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:36724). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1056: DB::TCPHandler::startInsertQuery(DB::QueryState&) @ 0x000000003ade049b 8. ./build_docker/./src/Server/TCPHandler.cpp:1117: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003adbb0d8 9. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x000000003ad8e9f8 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:23:43.852435 [ 53308 ] {e5bbc634-3a05-4c4d-b727-cde96e6f8e82} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:36724). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36724) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_alter_add_drop_3 VALUES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1056: DB::TCPHandler::startInsertQuery(DB::QueryState&) @ 0x000000003ade049b 8. ./build_docker/./src/Server/TCPHandler.cpp:1117: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003adbb0d8 9. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x000000003ad8e9f8 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:23:43.863581 [ 53308 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:36724). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003ade1ccb 7. ./build_docker/./src/Server/TCPHandler.cpp:1056: DB::TCPHandler::startInsertQuery(DB::QueryState&) @ 0x000000003ade049b 8. ./build_docker/./src/Server/TCPHandler.cpp:1117: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003adbb0d8 9. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x000000003ad8e9f8 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:25:14.239190 [ 37793 ] {ca198aff-1a32-4ca6-8226-8a1725fb67d9} ExternalDictionariesLoader: Could not load external dictionary 'a7f51d4a-b648-49ae-81f8-ef223cb7be3a', next update is scheduled at 2025-06-13 09:25:19: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.non_existing_table' in scope SELECT key_column, second_column, third_column, fourth_column FROM database_for_dict.non_existing_table. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000026edde23 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:116: DB::ClickHouseDictionarySource::loadAll() @ 0x0000000026edd795 18. DB::HashedDictionary<(DB::DictionaryKeyType)0, false, false>::loadData() @ 0x00000000281856e4 19. DB::HashedDictionary<(DB::DictionaryKeyType)0, false, false>::HashedDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::HashedDictionaryConfiguration const&, std::shared_ptr) @ 0x00000000281843dc 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::registerDictionaryHashed(DB::DictionaryFactory&)::$_4::operator()(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, DB::DictionaryKeyType, bool) const @ 0x000000002793ccc6 21. ./build_docker/./src/Dictionaries/registerHashedDictionary.cpp:125: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000027938a9f 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 23. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 24. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 25. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 26. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 31. ? @ 0x00007f5206343ac3 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. ./build_docker/./src/Storages/StorageDictionary.cpp:188: DB::StorageDictionary::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003833e124 11. ./build_docker/./src/Storages/IStorage.cpp:184: DB::IStorage::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003824cc3d 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032b6f004 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032b5101c 14. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x0000000032afc62e 15. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:14.251313 [ 53310 ] {ca198aff-1a32-4ca6-8226-8a1725fb67d9} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.non_existing_table' in scope SELECT key_column, second_column, third_column, fourth_column FROM database_for_dict.non_existing_table. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47846) (comment: 01018_dictionaries_from_dictionaries.sql) (query 22, line 91) (in query: SELECT count(*) FROM database_for_dict.dict4;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000026edde23 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:116: DB::ClickHouseDictionarySource::loadAll() @ 0x0000000026edd795 18. DB::HashedDictionary<(DB::DictionaryKeyType)0, false, false>::loadData() @ 0x00000000281856e4 19. DB::HashedDictionary<(DB::DictionaryKeyType)0, false, false>::HashedDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::HashedDictionaryConfiguration const&, std::shared_ptr) @ 0x00000000281843dc 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::registerDictionaryHashed(DB::DictionaryFactory&)::$_4::operator()(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, DB::DictionaryKeyType, bool) const @ 0x000000002793ccc6 21. ./build_docker/./src/Dictionaries/registerHashedDictionary.cpp:125: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000027938a9f 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 23. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 24. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 25. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 26. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 31. ? @ 0x00007f5206343ac3 2025.06.13 09:25:14.261368 [ 53310 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'database_for_dict.non_existing_table' in scope SELECT key_column, second_column, third_column, fourth_column FROM database_for_dict.non_existing_table. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a256bed 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c6286 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000026edde23 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:116: DB::ClickHouseDictionarySource::loadAll() @ 0x0000000026edd795 18. DB::HashedDictionary<(DB::DictionaryKeyType)0, false, false>::loadData() @ 0x00000000281856e4 19. DB::HashedDictionary<(DB::DictionaryKeyType)0, false, false>::HashedDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::HashedDictionaryConfiguration const&, std::shared_ptr) @ 0x00000000281843dc 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::registerDictionaryHashed(DB::DictionaryFactory&)::$_4::operator()(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, DB::DictionaryKeyType, bool) const @ 0x000000002793ccc6 21. ./build_docker/./src/Dictionaries/registerHashedDictionary.cpp:125: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000027938a9f 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bfc71d1 23. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002bfc53bd 24. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000327bd4e0 25. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1512: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000327eaeea 26. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000327e6c31 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000327f59a9 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000327f543f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 31. ? @ 0x00007f5206343ac3 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000327e8eb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000327e1a3e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003282b514 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000327d36fd 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000327d4079 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000327bf958 10. ./build_docker/./src/Storages/StorageDictionary.cpp:188: DB::StorageDictionary::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003833e124 11. ./build_docker/./src/Storages/IStorage.cpp:184: DB::IStorage::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003824cc3d 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032b6f004 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032b5101c 14. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x0000000032afc62e 15. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032aedcb2 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032ae5fd2 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730e02 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 2025.06.13 09:25:15.038076 [ 53310 ] {b460617b-9f6e-480a-8240-9d6e31a6d622} executeQuery: Code: 81. DB::Exception: Database database_for_dict does not exist. (UNKNOWN_DATABASE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47846) (comment: 01018_dictionaries_from_dictionaries.sql) (query 26, line 98) (in query: SELECT count(*) from database_for_dict.dict3;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Interpreters/Context.cpp:5680: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000003174f585 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:161: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x0000000031022964 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035d64c 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4364: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c4340 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 09:25:15.045708 [ 53310 ] {} TCPHandler: Code: 81. DB::Exception: Database database_for_dict does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Interpreters/Context.cpp:5680: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000003174f585 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:161: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x0000000031022964 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035d64c 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4364: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c4340 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 09:25:15.081557 [ 53310 ] {b6657bef-8e96-487c-9a53-c32d539cab65} executeQuery: Code: 81. DB::Exception: Database database_for_dict does not exist. (UNKNOWN_DATABASE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47846) (comment: 01018_dictionaries_from_dictionaries.sql) (query 27, line 99) (in query: SELECT count(*) from database_for_dict.dict2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Interpreters/Context.cpp:5680: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000003174f585 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:161: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x0000000031022964 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035d64c 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4364: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c4340 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 09:25:15.088571 [ 53310 ] {} TCPHandler: Code: 81. DB::Exception: Database database_for_dict does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Interpreters/Context.cpp:5680: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000003174f585 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:161: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x0000000031022964 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035d64c 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4364: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c4340 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 09:25:15.125767 [ 53310 ] {20770e85-1d1f-46f3-91bd-42d0b19e08f8} executeQuery: Code: 81. DB::Exception: Database database_for_dict does not exist. (UNKNOWN_DATABASE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47846) (comment: 01018_dictionaries_from_dictionaries.sql) (query 28, line 100) (in query: SELECT count(*) from database_for_dict.dict1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Interpreters/Context.cpp:5680: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000003174f585 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:161: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x0000000031022964 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035d64c 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4364: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c4340 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 09:25:15.134039 [ 53310 ] {} TCPHandler: Code: 81. DB::Exception: Database database_for_dict does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008bc286a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031a07906 5. ./build_docker/./src/Interpreters/Context.cpp:5680: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000003174f585 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:161: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x0000000031022964 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003035d64c 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4364: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000303c4340 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003030c37f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030308de6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030307679 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030477699 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032ae33af 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032add00e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032ae6b32 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032ae66b3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000329bd74f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033730590 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 27. ? @ 0x00007f5206343ac3 28. ? @ 0x00007f52063d5850 2025.06.13 09:25:16.448951 [ 53310 ] {c46f154a-dffd-426c-9d68-af5883112e48} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 31.51 MiB (attempt to allocate chunk of 1.01 MiB bytes), maximum: 30.52 MiB.: While executing FillingRightJoinSide. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49758) (comment: 01010_pmj_right_table_memory_limits.sql) (query 5, line 8) (in query: SELECT n, j FROM ( SELECT number * 200000 as n FROM numbers(5) ) nums ANY LEFT JOIN ( SELECT number * 2 AS n, number AS j FROM numbers(1000000) ) js2 USING n;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f53f624 8. ./src/Common/HashTable/HashTable.h:538: HashTable, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator>::resize(unsigned long, unsigned long) @ 0x00000000327693d7 9. ./src/Common/HashTable/HashTable.h:926: void DB::HashJoinMethods<(DB::JoinKind)1, (DB::JoinStrictness)2, DB::HashJoin::MapsTemplate>::insertFromBlockImplTypeCase, DB::RowRef, unsigned long, false, true, false>, TwoLevelHashMapTable, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>, DB::ColumnVector>(DB::HashJoin&, TwoLevelHashMapTable, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>&, std::vector> const&, std::vector> const&, DB::Block const*, DB::ColumnVector const&, DB::PODArray, 63ul, 64ul> const*, DB::PODArray, 63ul, 64ul> const*, DB::Arena&, bool&) @ 0x0000000035451b9e 10. ./src/Interpreters/HashJoin/HashJoinMethodsImpl.h:51: DB::HashJoinMethods<(DB::JoinKind)1, (DB::JoinStrictness)2, DB::HashJoin::MapsTemplate>::insertFromBlockImpl(DB::HashJoin&, DB::HashJoin::Type, DB::HashJoin::MapsTemplate&, std::vector> const&, std::vector> const&, DB::Block const*, DB::detail::Selector const&, DB::PODArray, 63ul, 64ul> const*, DB::PODArray, 63ul, 64ul> const*, DB::Arena&, bool&) @ 0x0000000035430dfa 11. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:717: DB::HashJoin::addBlockToJoin(DB::ScatteredBlock&, bool) @ 0x0000000033ad778c 12. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:280: DB::ConcurrentHashJoin::addBlockToJoin(DB::Block const&, bool) @ 0x000000003271ba99 13. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:357: DB::FillingRightJoinSideTransform::work() @ 0x000000003ba38038 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 2025.06.13 09:25:16.520364 [ 53310 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 31.51 MiB (attempt to allocate chunk of 1.01 MiB bytes), maximum: 30.52 MiB.: While executing FillingRightJoinSide. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f53f624 8. ./src/Common/HashTable/HashTable.h:538: HashTable, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator>::resize(unsigned long, unsigned long) @ 0x00000000327693d7 9. ./src/Common/HashTable/HashTable.h:926: void DB::HashJoinMethods<(DB::JoinKind)1, (DB::JoinStrictness)2, DB::HashJoin::MapsTemplate>::insertFromBlockImplTypeCase, DB::RowRef, unsigned long, false, true, false>, TwoLevelHashMapTable, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>, DB::ColumnVector>(DB::HashJoin&, TwoLevelHashMapTable, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>&, std::vector> const&, std::vector> const&, DB::Block const*, DB::ColumnVector const&, DB::PODArray, 63ul, 64ul> const*, DB::PODArray, 63ul, 64ul> const*, DB::Arena&, bool&) @ 0x0000000035451b9e 10. ./src/Interpreters/HashJoin/HashJoinMethodsImpl.h:51: DB::HashJoinMethods<(DB::JoinKind)1, (DB::JoinStrictness)2, DB::HashJoin::MapsTemplate>::insertFromBlockImpl(DB::HashJoin&, DB::HashJoin::Type, DB::HashJoin::MapsTemplate&, std::vector> const&, std::vector> const&, DB::Block const*, DB::detail::Selector const&, DB::PODArray, 63ul, 64ul> const*, DB::PODArray, 63ul, 64ul> const*, DB::Arena&, bool&) @ 0x0000000035430dfa 11. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:717: DB::HashJoin::addBlockToJoin(DB::ScatteredBlock&, bool) @ 0x0000000033ad778c 12. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:280: DB::ConcurrentHashJoin::addBlockToJoin(DB::Block const&, bool) @ 0x000000003271ba99 13. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:357: DB::FillingRightJoinSideTransform::work() @ 0x000000003ba38038 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b0b3c0d 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9d815f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001f9d6d2a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b0b32bb 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeba0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 10. ? @ 0x00007f5206343ac3 11. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:25:16.935759 [ 53310 ] {5f26fce6-1b8f-473d-bd19-20e33e8bce5c} executeQuery: Code: 12. DB::Exception: No limit for MergeJoin (max_rows_in_join or max_bytes_in_join settings must be set). (PARAMETER_OUT_OF_BOUND) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49758) (comment: 01010_pmj_right_table_memory_limits.sql) (query 8, line 21) (in query: SELECT n, j FROM ( SELECT number * 200000 as n FROM numbers(5) ) nums ANY LEFT JOIN ( SELECT number * 2 AS n, number AS j FROM numbers(1000000) ) js2 USING n;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/MergeJoin.cpp:519: DB::MergeJoin::MergeJoin(std::shared_ptr, DB::Block const&) @ 0x0000000032d61618 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, DB::Block const&, 0>(std::allocator const&, std::shared_ptr&, DB::Block const&) @ 0x0000000031b40192 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x0000000032bf2bf9 7. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003c09e07a 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x000000003c3e710a 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c3be655 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f95f8 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 2025.06.13 09:25:16.946607 [ 53310 ] {} TCPHandler: Code: 12. DB::Exception: No limit for MergeJoin (max_rows_in_join or max_bytes_in_join settings must be set). (PARAMETER_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Interpreters/MergeJoin.cpp:519: DB::MergeJoin::MergeJoin(std::shared_ptr, DB::Block const&) @ 0x0000000032d61618 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, DB::Block const&, 0>(std::allocator const&, std::shared_ptr&, DB::Block const&) @ 0x0000000031b40192 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x0000000032bf2bf9 7. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003c09e07a 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x000000003c3e710a 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c3be655 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c0f95f8 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032ae5cfb 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032ae5681 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 2025.06.13 09:25:17.494636 [ 53310 ] {d0623f27-9add-462b-91eb-0f2ca68caccc} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 31.41 MiB (attempt to allocate chunk of 1.50 MiB bytes), maximum: 30.52 MiB.: While executing MergeSortingTransform: While executing FillingRightJoinSide. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49758) (comment: 01010_pmj_right_table_memory_limits.sql) (query 9, line 31) (in query: SELECT n, j FROM ( SELECT number * 200000 as n FROM numbers(5) ) nums ANY LEFT JOIN ( SELECT number * 2 AS n, number AS j FROM numbers(1000000) ) js2 USING n SETTINGS max_bytes_in_join = 30000000;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f53d7c4 8. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008ba5855 9. ./build_docker/./src/Columns/ColumnVector.cpp:530: DB::ColumnVector::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000037a1bb6d 10. ./src/Columns/IColumn.h:210: DB::Chunk DB::MergeSorter::mergeBatchImpl>, (DB::SortingQueueStrategy)1>>(DB::SortingQueueImpl>, (DB::SortingQueueStrategy)1>&) @ 0x000000003bb60b7c 11. ./build_docker/./src/Processors/Transforms/SortingTransform.cpp:75: _ZNSt3__116__variant_detail12__visitation6__base12__dispatcherIJLm3EEE10__dispatchB8ne190107IONS1_9__variant15__value_visitorIRZN2DB11MergeSorter4readEvE3$_0EEJRNS0_6__baseILNS0_6_TraitE1EJNS8_16SortingQueueImplINS8_33SpecializedSingleColumnSortCursorINS8_12ColumnVectorIDuEEEELNS8_20SortingQueueStrategyE1EEENSG_INSH_INSI_ItEEEELSL_1EEENSG_INSH_INSI_IjEEEELSL_1EEENSG_INSH_INSI_ImEEEELSL_1EEENSG_INSH_INSI_IN4wide7integerILm128EjEEEEEELSL_1EEENSG_INSH_INSI_INSX_ILm256EjEEEEEELSL_1EEENSG_INSH_INSI_IDB8_EEEELSL_1EEENSG_INSH_INSI_IsEEEELSL_1EEENSG_INSH_INSI_IiEEEELSL_1EEENSG_INSH_INSI_IlEEEELSL_1EEENSG_INSH_INSI_INSX_ILm128EiEEEEEELSL_1EEENSG_INSH_INSI_INSX_ILm256EiEEEEEELSL_1EEENSG_INSH_INSI_I8BFloat16EEEELSL_1EEENSG_INSH_INSI_IfEEEELSL_1EEENSG_INSH_INSI_IdEEEELSL_1EEENSG_INSH_INS8_13ColumnDecimalINS8_7DecimalIiEEEEEELSL_1EEENSG_INSH_INS21_INS22_IlEEEEEELSL_1EEENSG_INSH_INS21_INS22_IS1J_EEEEEELSL_1EEENSG_INSH_INS21_INS22_IS1N_EEEEEELSL_1EEENSG_INSH_INS21_INS8_10DateTime64EEEEELSL_1EEENSG_INSH_INSI_I13StrongTypedefISY_NS8_7UUIDTagEEEEEELSL_1EEENSG_INSH_INSI_INS8_4IPv4EEEEELSL_1EEENSG_INSH_INSI_INS8_4IPv6EEEEELSL_1EEENSG_INSH_INS8_12ColumnStringEEELSL_1EEENSG_INSH_INS8_17ColumnFixedStringEEELSL_1EEENSG_INS8_16SimpleSortCursorELSL_1EEENSG_INS8_10SortCursorELSL_1EEENSG_INS8_23SortCursorWithCollationELSL_1EEEEEEEEEDcT_DpT0_ @ 0x000000003bae6653 12. ./contrib/llvm-project/libcxx/include/variant:508: DB::MergeSorter::read() @ 0x000000003bace0c4 13. ./build_docker/./src/Processors/Transforms/MergeSortingTransform.cpp:265: DB::MergeSortingTransform::generate() @ 0x000000003ba8fcdb 14. ./build_docker/./src/Processors/Transforms/SortingTransform.cpp:354: DB::SortingTransform::work() @ 0x000000003badf6b8 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b0f6008 20. ./build_docker/./src/Interpreters/MergeJoin.cpp:622: DB::MergeJoin::mergeInMemoryRightBlocks() @ 0x0000000032d658d7 21. ./build_docker/./src/Interpreters/MergeJoin.cpp:585: DB::MergeJoin::setTotals(DB::Block const&) @ 0x0000000032d63fb2 22. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:353: DB::FillingRightJoinSideTransform::work() @ 0x000000003ba37f9a 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 27. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 2025.06.13 09:25:17.517793 [ 53310 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 31.41 MiB (attempt to allocate chunk of 1.50 MiB bytes), maximum: 30.52 MiB.: While executing MergeSortingTransform: While executing FillingRightJoinSide. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f76c4fc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f768800 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f7677ff 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::alloc(long) @ 0x000000001f542247 7. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f53d7c4 8. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008ba5855 9. ./build_docker/./src/Columns/ColumnVector.cpp:530: DB::ColumnVector::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000037a1bb6d 10. ./src/Columns/IColumn.h:210: DB::Chunk DB::MergeSorter::mergeBatchImpl>, (DB::SortingQueueStrategy)1>>(DB::SortingQueueImpl>, (DB::SortingQueueStrategy)1>&) @ 0x000000003bb60b7c 11. ./build_docker/./src/Processors/Transforms/SortingTransform.cpp:75: _ZNSt3__116__variant_detail12__visitation6__base12__dispatcherIJLm3EEE10__dispatchB8ne190107IONS1_9__variant15__value_visitorIRZN2DB11MergeSorter4readEvE3$_0EEJRNS0_6__baseILNS0_6_TraitE1EJNS8_16SortingQueueImplINS8_33SpecializedSingleColumnSortCursorINS8_12ColumnVectorIDuEEEELNS8_20SortingQueueStrategyE1EEENSG_INSH_INSI_ItEEEELSL_1EEENSG_INSH_INSI_IjEEEELSL_1EEENSG_INSH_INSI_ImEEEELSL_1EEENSG_INSH_INSI_IN4wide7integerILm128EjEEEEEELSL_1EEENSG_INSH_INSI_INSX_ILm256EjEEEEEELSL_1EEENSG_INSH_INSI_IDB8_EEEELSL_1EEENSG_INSH_INSI_IsEEEELSL_1EEENSG_INSH_INSI_IiEEEELSL_1EEENSG_INSH_INSI_IlEEEELSL_1EEENSG_INSH_INSI_INSX_ILm128EiEEEEEELSL_1EEENSG_INSH_INSI_INSX_ILm256EiEEEEEELSL_1EEENSG_INSH_INSI_I8BFloat16EEEELSL_1EEENSG_INSH_INSI_IfEEEELSL_1EEENSG_INSH_INSI_IdEEEELSL_1EEENSG_INSH_INS8_13ColumnDecimalINS8_7DecimalIiEEEEEELSL_1EEENSG_INSH_INS21_INS22_IlEEEEEELSL_1EEENSG_INSH_INS21_INS22_IS1J_EEEEEELSL_1EEENSG_INSH_INS21_INS22_IS1N_EEEEEELSL_1EEENSG_INSH_INS21_INS8_10DateTime64EEEEELSL_1EEENSG_INSH_INSI_I13StrongTypedefISY_NS8_7UUIDTagEEEEEELSL_1EEENSG_INSH_INSI_INS8_4IPv4EEEEELSL_1EEENSG_INSH_INSI_INS8_4IPv6EEEEELSL_1EEENSG_INSH_INS8_12ColumnStringEEELSL_1EEENSG_INSH_INS8_17ColumnFixedStringEEELSL_1EEENSG_INS8_16SimpleSortCursorELSL_1EEENSG_INS8_10SortCursorELSL_1EEENSG_INS8_23SortCursorWithCollationELSL_1EEEEEEEEEDcT_DpT0_ @ 0x000000003bae6653 12. ./contrib/llvm-project/libcxx/include/variant:508: DB::MergeSorter::read() @ 0x000000003bace0c4 13. ./build_docker/./src/Processors/Transforms/MergeSortingTransform.cpp:265: DB::MergeSortingTransform::generate() @ 0x000000003ba8fcdb 14. ./build_docker/./src/Processors/Transforms/SortingTransform.cpp:354: DB::SortingTransform::work() @ 0x000000003badf6b8 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b0f6008 20. ./build_docker/./src/Interpreters/MergeJoin.cpp:622: DB::MergeJoin::mergeInMemoryRightBlocks() @ 0x0000000032d658d7 21. ./build_docker/./src/Interpreters/MergeJoin.cpp:585: DB::MergeJoin::setTotals(DB::Block const&) @ 0x0000000032d63fb2 22. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:353: DB::FillingRightJoinSideTransform::work() @ 0x000000003ba37f9a 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 27. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0f3617 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 30. ? @ 0x00007f5206343ac3 31. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b0ef15d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b0f030b 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe41f 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:25:23.854320 [ 53323 ] {435c0e1b-ae79-4a37-8573-eb4c24e9cdbe} executeQuery: Code: 60. DB::Exception: Could not find table: alter_table_2. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56090) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE alter_table_2 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032897f5a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:25:23.854373 [ 55426 ] {c9c121f9-62cf-41e0-a6eb-1fae127ccd76} executeQuery: Code: 60. DB::Exception: Could not find table: alter_table_4. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56116) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE alter_table_4 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032897f5a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:25:23.883034 [ 53323 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_table_2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032897f5a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:25:23.884483 [ 55426 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_table_4. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032897f5a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:25:23.937400 [ 53310 ] {7c1c8898-d12c-4d55-9978-ad673a06be46} executeQuery: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_7 does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56072) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO alter_table_7 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8528 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000329c69b4 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x00000000329e278f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:25:23.985398 [ 53310 ] {} TCPHandler: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_7 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8528 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000329c69b4 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x00000000329e278f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:25:24.078175 [ 55423 ] {ca5d8979-e08d-40ea-b3a0-61de9bc8e56f} executeQuery: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_0 does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56110) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE alter_table_0 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8528 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000003385732a 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:25:24.146609 [ 55423 ] {} TCPHandler: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_0 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008b9e42d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8528 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000003385732a 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:25:24.177335 [ 53323 ] {70a66a16-c455-4000-8938-87da1d027927} executeQuery: Code: 60. DB::Exception: Could not find table: alter_table_9. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56134) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE alter_table_9 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032897f5a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:25:24.201229 [ 53323 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_table_9. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032897f5a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:25:24.483718 [ 55426 ] {f0ca7076-f0f5-47fe-b6d3-9782d041e1b7} executeQuery: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_5 does not exist. Maybe you meant test_ecou59xi.alter_table_7?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56182) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO alter_table_5 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000329c69b4 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x00000000329e278f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:25:24.505662 [ 55426 ] {} TCPHandler: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_5 does not exist. Maybe you meant test_ecou59xi.alter_table_7?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000329c69b4 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x00000000329e278f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:25:24.599566 [ 55456 ] {5ba1e46e-29a6-498a-a307-47b2c19a4134} executeQuery: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_2 does not exist. Maybe you meant test_ecou59xi.alter_table_3?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56236) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO alter_table_2 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000329c69b4 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x00000000329e278f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:25:24.612153 [ 55450 ] {3a21f465-5504-47f3-a6f0-8cbeb5dad4d2} executeQuery: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_0 does not exist. Maybe you meant test_ecou59xi.alter_table_3?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56204) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE alter_table_0 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000003385732a 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:25:24.612352 [ 55455 ] {90bb29c8-992a-4ab8-b9d0-b272a70cea27} executeQuery: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_5 does not exist. Maybe you meant test_ecou59xi.alter_table_3?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56234) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE alter_table_5 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000003385732a 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:25:24.618548 [ 55463 ] {36e7e33b-91ff-416a-adce-64fe6215d588} executeQuery: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_8 does not exist. Maybe you meant test_ecou59xi.alter_table_3?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56270) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE alter_table_8 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000003385732a 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:25:24.624827 [ 55456 ] {} TCPHandler: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_2 does not exist. Maybe you meant test_ecou59xi.alter_table_3?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000329c69b4 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x00000000329e278f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:25:24.624986 [ 55455 ] {} TCPHandler: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_5 does not exist. Maybe you meant test_ecou59xi.alter_table_3?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000003385732a 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:25:24.632521 [ 55450 ] {} TCPHandler: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_0 does not exist. Maybe you meant test_ecou59xi.alter_table_3?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000003385732a 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:25:24.662382 [ 55463 ] {} TCPHandler: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_8 does not exist. Maybe you meant test_ecou59xi.alter_table_3?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000003385732a 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:25:24.696732 [ 55444 ] {3703af15-3b23-4db0-a659-6775f50e8b80} executeQuery: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_4 does not exist. Maybe you meant test_ecou59xi.alter_table_3?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56196) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO alter_table_4 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000329c69b4 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x00000000329e278f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:25:24.771390 [ 55444 ] {} TCPHandler: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_4 does not exist. Maybe you meant test_ecou59xi.alter_table_3?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000329c69b4 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x00000000329e278f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:25:25.099658 [ 53314 ] {422be7a9-53cc-4143-a14e-7ce1b06ac495} executeQuery: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_1 does not exist. Maybe you meant test_ecou59xi.alter_table_0?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56280) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO alter_table_1 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000329c69b4 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x00000000329e278f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:25:25.111440 [ 53314 ] {} TCPHandler: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_1 does not exist. Maybe you meant test_ecou59xi.alter_table_0?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000329c69b4 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x00000000329e278f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:25:25.196251 [ 53323 ] {f75e2d68-0be5-44d4-85d5-fbc8a50687d4} executeQuery: Code: 60. DB::Exception: Could not find table: alter_table_6. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56282) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE alter_table_6 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032897f5a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:25:25.215021 [ 53323 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_table_6. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032897f5a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:25:25.377618 [ 55425 ] {321c922a-1185-453c-bc06-d6b83b283a2e} executeQuery: Code: 60. DB::Exception: Could not find table: alter_table_1. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56308) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE alter_table_1 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032897f5a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:25:25.415753 [ 55425 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_table_1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032897f5a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:25:25.719674 [ 53323 ] {c0d90e14-bed6-4504-b789-9f7518e701ac} executeQuery: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_8 does not exist. Maybe you meant test_ecou59xi.alter_table_0?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56338) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO alter_table_8 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000329c69b4 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x00000000329e278f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:25:25.754082 [ 53323 ] {} TCPHandler: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_8 does not exist. Maybe you meant test_ecou59xi.alter_table_0?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000329c69b4 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x00000000329e278f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:25:25.811142 [ 53314 ] {acc28c66-606d-4b10-a655-66eca26f5d92} executeQuery: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_8 does not exist. Maybe you meant test_ecou59xi.alter_table_0?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56356) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO alter_table_8 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000329c69b4 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x00000000329e278f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:25:25.839783 [ 53314 ] {} TCPHandler: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_8 does not exist. Maybe you meant test_ecou59xi.alter_table_0?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000329c69b4 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x00000000329e278f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:25:26.203898 [ 55422 ] {7d2d7707-343c-4412-9b4b-3cef9dc941c5} executeQuery: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_8 does not exist. Maybe you meant test_ecou59xi.alter_table_0?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56388) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE alter_table_8 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000003385732a 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:25:26.220127 [ 55422 ] {} TCPHandler: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_8 does not exist. Maybe you meant test_ecou59xi.alter_table_0?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000003385732a 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:25:26.472266 [ 55425 ] {79ea2448-73e2-45d7-baf9-d2d5e0bf0f5c} executeQuery: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_1 does not exist. Maybe you meant test_ecou59xi.alter_table_0?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56410) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO alter_table_1 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000329c69b4 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x00000000329e278f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:25:26.547088 [ 55425 ] {} TCPHandler: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_1 does not exist. Maybe you meant test_ecou59xi.alter_table_0?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000329c69b4 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x00000000329e278f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:25:26.843584 [ 55425 ] {52b1ad2d-b387-4640-a451-d56431296788} executeQuery: Code: 60. DB::Exception: Could not find table: alter_table_1. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56488) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE alter_table_1 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032897f5a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:25:26.869747 [ 55425 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_table_1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032897f5a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:25:26.969321 [ 55450 ] {acba6d40-415b-45e3-9728-c824f8d82a7a} executeQuery: Code: 60. DB::Exception: Could not find table: alter_table_1. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56510) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE alter_table_1 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032897f5a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:25:27.017194 [ 55450 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_table_1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032897f5a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:25:27.253377 [ 55456 ] {30dba89f-e425-46a2-9d86-1ba346680513} executeQuery: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_1 does not exist. Maybe you meant test_ecou59xi.alter_table_0?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56542) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO alter_table_1 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000329c69b4 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x00000000329e278f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:25:27.281690 [ 55456 ] {} TCPHandler: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_1 does not exist. Maybe you meant test_ecou59xi.alter_table_0?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000329c69b4 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x00000000329e278f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:25:28.033816 [ 55463 ] {e1b1be29-db59-4dee-9d96-d7e927fb8d9f} executeQuery: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_5 does not exist. Maybe you meant test_ecou59xi.alter_table_3?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56580) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE alter_table_5 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000003385732a 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:25:28.053544 [ 55463 ] {} TCPHandler: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_5 does not exist. Maybe you meant test_ecou59xi.alter_table_3?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000003385732a 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:25:28.244478 [ 53310 ] {23299e4d-6554-4bca-adc8-bbdca379189b} executeQuery: Code: 60. DB::Exception: Could not find table: alter_table_8. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56628) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE alter_table_8 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032897f5a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:25:28.275020 [ 53310 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_table_8. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032897f5a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:25:28.337316 [ 55422 ] {daa9691a-6325-4225-b0cf-58a7615623b7} executeQuery: Code: 60. DB::Exception: Could not find table: alter_table_0. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56652) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE alter_table_0 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032897f5a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:25:28.406850 [ 55422 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_table_0. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032897f5a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:25:28.544944 [ 55464 ] {1238e029-c882-4c31-b1e4-8bc8a3f18d18} executeQuery: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_5 does not exist. Maybe you meant test_ecou59xi.alter_table_3?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56668) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE alter_table_5 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000003385732a 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:25:28.580573 [ 55464 ] {} TCPHandler: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_5 does not exist. Maybe you meant test_ecou59xi.alter_table_3?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000003385732a 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:25:29.591851 [ 55461 ] {cd65bb97-a55e-4c4d-bf98-011df6f9200e} executeQuery: Code: 60. DB::Exception: Could not find table: alter_table_9. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56814) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE alter_table_9 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032897f5a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:25:29.631684 [ 55461 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_table_9. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032897f5a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:25:29.817513 [ 53323 ] {940043f9-5f95-4f0e-8c18-ddf3fda241dc} executeQuery: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_0 does not exist. Maybe you meant test_ecou59xi.alter_table_2?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56824) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE alter_table_0 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000003385732a 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:25:29.831853 [ 55426 ] {183d8330-9e54-4f3c-8e2a-3e28d06b046c} executeQuery: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_8 does not exist. Maybe you meant test_ecou59xi.alter_table_2?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56790) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE alter_table_8 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000003385732a 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:25:29.865866 [ 53323 ] {} TCPHandler: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_0 does not exist. Maybe you meant test_ecou59xi.alter_table_2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000003385732a 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:25:29.883095 [ 55426 ] {} TCPHandler: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_8 does not exist. Maybe you meant test_ecou59xi.alter_table_2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000003385732a 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:25:30.129598 [ 55422 ] {f046a277-bc7f-42d6-82f0-c72a9a7902e1} executeQuery: Code: 60. DB::Exception: Could not find table: alter_table_1. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56856) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE alter_table_1 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032897f5a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:25:30.151139 [ 55422 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_table_1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032897f5a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:25:30.775139 [ 55463 ] {603f6e33-719d-4c43-ad3d-58bb9d419b16} executeQuery: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_3). (TABLE_IS_READ_ONLY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56654) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE alter_table_3 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5937: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000387c001e 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:329: DB::StorageReplicatedMergeTree::waitForProcessingQueue(unsigned long, DB::SyncReplicaMode, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000038b01d7c 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6236: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr)::$_1::operator()(String const&) const @ 0x00000000389efc5d 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6296: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000389e9835 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000033858e79 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:25:30.814748 [ 55463 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5937: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000387c001e 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:329: DB::StorageReplicatedMergeTree::waitForProcessingQueue(unsigned long, DB::SyncReplicaMode, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000038b01d7c 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6236: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr)::$_1::operator()(String const&) const @ 0x00000000389efc5d 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6296: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000389e9835 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000033858e79 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:25:30.834297 [ 55461 ] {b718eea1-e8c1-4c93-baec-80adf8f71b24} executeQuery: Code: 60. DB::Exception: Could not find table: alter_table_1. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56910) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE alter_table_1 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032897f5a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:25:30.863288 [ 55461 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_table_1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032897f5a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:25:31.134320 [ 55422 ] {a58f6224-670d-4004-a061-a8aa47f2bb69} executeQuery: Code: 236. DB::Exception: Cannot assign mutation because shutdown called. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56938) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE alter_table_3 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7902: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x0000000038a8792b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000328959f3 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:25:31.156093 [ 55422 ] {} TCPHandler: Code: 236. DB::Exception: Cannot assign mutation because shutdown called. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7902: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x0000000038a8792b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000328959f3 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:25:31.272970 [ 55673 ] {fe3bcf1e-cbfc-4ff6-93aa-238693a2ea76} executeQuery: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_8 does not exist. Maybe you meant test_ecou59xi.alter_table_2?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56950) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE alter_table_8 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000003385732a 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:25:31.292891 [ 55673 ] {} TCPHandler: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_8 does not exist. Maybe you meant test_ecou59xi.alter_table_2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000003385732a 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:25:31.602169 [ 55691 ] {3412af20-fe36-4606-9e13-45e5f74fac32} executeQuery: Code: 60. DB::Exception: Could not find table: alter_table_1. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56998) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE alter_table_1 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032897f5a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:25:31.658750 [ 55691 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_table_1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032897f5a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:25:32.000419 [ 55685 ] {e2ea6f44-92b1-45e1-8f3a-1006769b30c6} executeQuery: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_4). (TABLE_IS_READ_ONLY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56970) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE alter_table_4 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5937: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000387c001e 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6118: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000389e71ad 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000033858e79 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:25:32.019167 [ 55685 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_4). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5937: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000387c001e 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6118: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000389e71ad 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000033858e79 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:25:32.492338 [ 55455 ] {cf740e71-70d9-4212-a3b5-f517113bdec6} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_3. (TABLE_IS_READ_ONLY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56536) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO alter_table_3 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000003a308e4e 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000003a301d3b 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()::operator()() const @ 0x000000003a3019c9 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000003a30131f 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a2c866d 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a29d717 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2c209b 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 14. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 19. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 2025.06.13 09:25:32.507833 [ 55464 ] {660c4ec8-9e0c-472c-8976-adc83022dbbf} executeQuery: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_1). (TABLE_IS_READ_ONLY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57098) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE alter_table_1 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5937: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000387c001e 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6118: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000389e71ad 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000033858e79 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:25:32.547187 [ 55464 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5937: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000387c001e 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6118: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000389e71ad 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000033858e79 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:25:32.729026 [ 55455 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_3. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000003a308e4e 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000003a301d3b 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()::operator()() const @ 0x000000003a3019c9 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000003a30131f 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a2c866d 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a29d717 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2c209b 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 14. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 19. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:25:32.888847 [ 55461 ] {37c826ce-299d-4f22-b430-ed8c0bc02ae4} executeQuery: Code: 236. DB::Exception: Cannot assign mutation because shutdown called. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57130) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE alter_table_4 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7902: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x0000000038a8792b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000328959f3 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:25:32.913235 [ 55461 ] {} TCPHandler: Code: 236. DB::Exception: Cannot assign mutation because shutdown called. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7902: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x0000000038a8792b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000328959f3 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:25:33.060825 [ 55444 ] {6d5091b8-ef12-4823-9813-fb479935d3c5} executeQuery: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_8 does not exist. Maybe you meant test_ecou59xi.alter_table_1?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57148) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE alter_table_8 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000003385732a 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:25:33.101336 [ 55444 ] {} TCPHandler: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_8 does not exist. Maybe you meant test_ecou59xi.alter_table_1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000003385732a 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:25:33.584997 [ 55455 ] {fd396ee1-9ce9-49eb-afb9-d63182d9a065} executeQuery: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_4 does not exist. Maybe you meant test_ecou59xi.alter_table_1?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53934) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE alter_table_4 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000003385732a 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:25:33.618669 [ 55455 ] {} TCPHandler: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_4 does not exist. Maybe you meant test_ecou59xi.alter_table_1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000003385732a 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:25:34.151451 [ 55444 ] {79db1d73-4cd2-4701-9a78-c39ed924fe05} executeQuery: Code: 236. DB::Exception: Cannot assign mutation because shutdown called. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53918) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE alter_table_1 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7902: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x0000000038a8792b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000328959f3 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:25:34.167790 [ 55444 ] {} TCPHandler: Code: 236. DB::Exception: Cannot assign mutation because shutdown called. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7902: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x0000000038a8792b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000328959f3 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:25:34.655869 [ 55459 ] {60645bce-351e-45bd-826a-04b8f99555bb} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_0. (TABLE_IS_READ_ONLY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56560) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO alter_table_0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000003a308e4e 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000003a301d3b 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()::operator()() const @ 0x000000003a3019c9 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000003a30131f 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a2c866d 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a29d717 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2c209b 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 14. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 19. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 2025.06.13 09:25:34.706146 [ 55459 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_0. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000003a308e4e 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000003a301d3b 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()::operator()() const @ 0x000000003a3019c9 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000003a30131f 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a2c866d 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a29d717 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2c209b 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 14. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 19. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:25:34.862215 [ 55461 ] {305bf6c2-14e7-4ea0-b3a5-46e4bf999601} executeQuery: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_3 does not exist. Maybe you meant test_ecou59xi.alter_table_1?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54066) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE alter_table_3 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000003385732a 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:25:34.877129 [ 55461 ] {} TCPHandler: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_3 does not exist. Maybe you meant test_ecou59xi.alter_table_1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000003385732a 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:25:35.173333 [ 55680 ] {a234a6d8-940a-4b00-8ba1-e35b756be022} executeQuery: Code: 60. DB::Exception: Could not find table: alter_table_0. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54126) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE alter_table_0 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032897f5a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:25:35.188279 [ 55680 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_table_0. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032897f5a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:25:35.293239 [ 1028 ] {} d4afa4a5-2ac7-410e-9a7f-7e4ee3b7c25d::-5_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Transaction failed (No node): Op #10, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_4/parts/-5_0_0_0_1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf01a33 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1602: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf02055 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2202: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x000000003887e6fe 6. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:241: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000039f8a64d 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:233: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a11353d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:35.293287 [ 1024 ] {} 783f6f8a-b74e-4ef6-af04-6de17418cbe8::-2_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Transaction failed (No node): Op #10, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_4/parts/-2_0_0_0_1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf01a33 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1602: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf02055 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2202: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x000000003887e6fe 6. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:241: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000039f8a64d 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:233: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a11353d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:35.293952 [ 1026 ] {} 783f6f8a-b74e-4ef6-af04-6de17418cbe8::-5_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Transaction failed (No node): Op #10, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_4/parts/-5_0_0_0_1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf01a33 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1602: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf02055 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2202: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x000000003887e6fe 6. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:241: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000039f8a64d 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:233: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a11353d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:35.295040 [ 1024 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {783f6f8a-b74e-4ef6-af04-6de17418cbe8::-2_0_0_0_1}: Code: 999. Coordination::Exception: Transaction failed (No node): Op #10, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_4/parts/-2_0_0_0_1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf01a33 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1602: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf02055 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2202: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x000000003887e6fe 6. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:241: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000039f8a64d 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:233: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a11353d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:35.295563 [ 1029 ] {} 510a46ab-4e47-4bd1-8720-9af536529205::-2_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_4/parts/-2_0_0_0_1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf01a33 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1602: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf02055 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2202: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x000000003887e6fe 6. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:241: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000039f8a64d 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:233: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a11353d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:35.296032 [ 1020 ] {} 510a46ab-4e47-4bd1-8720-9af536529205::-5_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Transaction failed (No node): Op #6, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_4/parts/-5_0_0_0_1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf01a33 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1602: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf02055 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2202: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x000000003887e6fe 6. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:241: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000039f8a64d 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:233: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a11353d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:35.295958 [ 1026 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {783f6f8a-b74e-4ef6-af04-6de17418cbe8::-5_0_0_0_1}: Code: 999. Coordination::Exception: Transaction failed (No node): Op #10, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_4/parts/-5_0_0_0_1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf01a33 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1602: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf02055 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2202: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x000000003887e6fe 6. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:241: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000039f8a64d 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:233: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a11353d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:35.297159 [ 1017 ] {} 783f6f8a-b74e-4ef6-af04-6de17418cbe8::0_1_1_0_2 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Transaction failed (No node): Op #10, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_4/parts/0_1_1_0_2. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf01a33 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1602: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf02055 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2202: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x000000003887e6fe 6. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:241: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000039f8a64d 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:233: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a11353d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:35.297893 [ 1029 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {510a46ab-4e47-4bd1-8720-9af536529205::-2_0_0_0_1}: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_4/parts/-2_0_0_0_1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf01a33 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1602: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf02055 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2202: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x000000003887e6fe 6. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:241: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000039f8a64d 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:233: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a11353d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:35.298505 [ 1028 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {d4afa4a5-2ac7-410e-9a7f-7e4ee3b7c25d::-5_0_0_0_1}: Code: 999. Coordination::Exception: Transaction failed (No node): Op #10, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_4/parts/-5_0_0_0_1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf01a33 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1602: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf02055 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2202: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x000000003887e6fe 6. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:241: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000039f8a64d 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:233: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a11353d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:35.298808 [ 1021 ] {} 510a46ab-4e47-4bd1-8720-9af536529205::0_1_1_0_2 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_4/parts/0_1_1_0_2. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf01a33 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1602: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf02055 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2202: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x000000003887e6fe 6. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:241: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000039f8a64d 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:233: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a11353d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:35.299549 [ 1021 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {510a46ab-4e47-4bd1-8720-9af536529205::0_1_1_0_2}: Code: 999. Coordination::Exception: Transaction failed (No node): Op #0, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_4/parts/0_1_1_0_2. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf01a33 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1602: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf02055 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2202: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x000000003887e6fe 6. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:241: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000039f8a64d 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:233: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a11353d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:35.300331 [ 1020 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {510a46ab-4e47-4bd1-8720-9af536529205::-5_0_0_0_1}: Code: 999. Coordination::Exception: Transaction failed (No node): Op #6, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_4/parts/-5_0_0_0_1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf01a33 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1602: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf02055 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2202: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x000000003887e6fe 6. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:241: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000039f8a64d 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:233: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a11353d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:35.298473 [ 1017 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {783f6f8a-b74e-4ef6-af04-6de17418cbe8::0_1_1_0_2}: Code: 999. Coordination::Exception: Transaction failed (No node): Op #10, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_4/parts/0_1_1_0_2. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf01a33 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1602: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf02055 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2202: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x000000003887e6fe 6. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:241: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000039f8a64d 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:233: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a11353d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:35.403113 [ 618 ] {} test_ecou59xi.alter_table_2 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_4/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000003ceb1f7a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:635: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003ced9d55 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:283: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a135a23 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a1316e5 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a12dce2 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a15759f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 10. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:35.403630 [ 414 ] {} test_ecou59xi.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_4/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000003ceb1f7a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:635: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003ced9d55 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:283: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a135a23 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a1316e5 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a12dce2 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a15759f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 10. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:35.403112 [ 692 ] {} test_ecou59xi.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_4/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000003ceb1f7a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:635: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003ced9d55 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:283: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a135a23 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a1316e5 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a12dce2 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a15759f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 10. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:35.546153 [ 648 ] {} test_ecou59xi.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_4/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000003ceb1f7a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:635: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003ced9d55 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:283: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a135a23 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a1316e5 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a12dce2 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a15759f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 10. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:35.620199 [ 55461 ] {585f8db3-55eb-46b8-82dc-f0074ee10770} executeQuery: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_1 does not exist. Maybe you meant test_ecou59xi.alter_table_2?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54150) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO alter_table_1 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000329c69b4 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x00000000329e278f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:25:35.651665 [ 55461 ] {} TCPHandler: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_1 does not exist. Maybe you meant test_ecou59xi.alter_table_2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000329c69b4 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x00000000329e278f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:25:35.821609 [ 718 ] {} test_ecou59xi.alter_table_6 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_4/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000003ceb1f7a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:635: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003ced9d55 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:283: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a135a23 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a1316e5 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a12dce2 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a15759f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 10. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:35.912702 [ 1015 ] {} 783f6f8a-b74e-4ef6-af04-6de17418cbe8::-8_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Transaction failed (No node): Op #4, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_0/parts/-8_0_0_0_1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf01a33 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1602: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf02055 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2202: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x000000003887e6fe 6. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:241: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000039f8a64d 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:233: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a11353d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:35.914434 [ 1015 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {783f6f8a-b74e-4ef6-af04-6de17418cbe8::-8_0_0_0_1}: Code: 999. Coordination::Exception: Transaction failed (No node): Op #4, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_0/parts/-8_0_0_0_1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf01a33 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1602: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf02055 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2202: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x000000003887e6fe 6. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:241: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000039f8a64d 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:233: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a11353d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:35.971720 [ 692 ] {} test_ecou59xi.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_0/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000003ceb1f7a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:635: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003ced9d55 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:283: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a135a23 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a1316e5 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a12dce2 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a15759f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 10. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:36.027791 [ 618 ] {} test_ecou59xi.alter_table_2 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_0/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000003ceb1f7a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:635: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003ced9d55 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:283: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a135a23 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a1316e5 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a12dce2 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a15759f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 10. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:36.148752 [ 689 ] {} test_ecou59xi.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_0/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000003ceb1f7a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:635: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003ced9d55 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:283: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a135a23 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a1316e5 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a12dce2 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a15759f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 10. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:36.610186 [ 643 ] {} test_ecou59xi.alter_table_4 (445fb1d3-87f1-4054-bae1-b8c392f97034): Log pointer of source replica r_2 changed while we loading queue nodes. Will retry. 2025.06.13 09:25:36.668824 [ 675 ] {} test_ecou59xi.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_1/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000003ceb1f7a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:635: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003ced9d55 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:283: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a135a23 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a1316e5 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a12dce2 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a15759f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 10. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:36.679783 [ 446 ] {} test_ecou59xi.alter_table_6 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_1/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000003ceb1f7a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:635: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003ced9d55 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:283: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a135a23 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a1316e5 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a12dce2 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a15759f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 10. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:36.747048 [ 618 ] {} test_ecou59xi.alter_table_2 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_1/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000003ceb1f7a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:635: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003ced9d55 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:283: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a135a23 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a1316e5 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a12dce2 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a15759f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 10. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:36.765564 [ 55693 ] {b3138427-bdc2-424b-b0d1-8d66fa58232e} executeQuery: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_9 does not exist. Maybe you meant test_ecou59xi.alter_table_2?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54264) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE alter_table_9 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000003385732a 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:25:36.826155 [ 55693 ] {} TCPHandler: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_9 does not exist. Maybe you meant test_ecou59xi.alter_table_2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000003385732a 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:25:36.863410 [ 732 ] {} test_ecou59xi.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_1/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000003ceb1f7a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:635: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003ced9d55 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:283: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a135a23 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a1316e5 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a12dce2 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a15759f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 10. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:36.943264 [ 55464 ] {c0b2f34b-baa5-41a7-8e52-af5bfa811147} executeQuery: Code: 60. DB::Exception: Could not find table: alter_table_1. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54238) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE alter_table_1 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032897f5a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:25:36.959103 [ 55464 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_table_1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032897f5a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:25:37.858598 [ 766 ] {} test_ecou59xi.alter_table_2 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Transaction failed (Bad version): Op #8, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf01a33 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1602: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf02055 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cede6f0 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:405: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a13b745 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a1316e5 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a12dce2 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a15759f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:37.858898 [ 847 ] {} test_ecou59xi.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Transaction failed (Bad version): Op #8, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf01a33 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1602: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf02055 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cede6f0 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:405: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a13b745 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a1316e5 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a12dce2 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a15759f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:37.864788 [ 485 ] {} test_ecou59xi.alter_table_6 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Transaction failed (Bad version): Op #8, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf01a33 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1602: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf02055 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cede6f0 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:405: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a13b745 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a1316e5 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a12dce2 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a15759f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:37.868359 [ 451 ] {} test_ecou59xi.alter_table_5 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Transaction failed (Bad version): Op #8, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf01a33 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1602: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf02055 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cede6f0 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:405: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a13b745 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a1316e5 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a12dce2 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a15759f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:38.030690 [ 55444 ] {622899f7-5a9f-4fa2-ab65-858e1637586c} executeQuery: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_0). (TABLE_IS_READ_ONLY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54370) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE alter_table_0 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5937: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000387c001e 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6118: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000389e71ad 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000033858e79 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:25:38.053160 [ 55444 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_0). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5937: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000387c001e 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6118: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000389e71ad 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000033858e79 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:25:38.729741 [ 55680 ] {45414f5d-8ca9-4851-b9a0-06edd3617613} executeQuery: Code: 60. DB::Exception: Could not find table: alter_table_8. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54430) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE alter_table_8 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032897f5a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:25:38.753581 [ 55680 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_table_8. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032897f5a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:25:40.254725 [ 55461 ] {ad3c27ce-1c7f-4bb6-ae79-368c758712f1} executeQuery: Code: 60. DB::Exception: Could not find table: alter_table_8. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54564) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE alter_table_8 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032897f5a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:25:40.272392 [ 55461 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_table_8. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032897f5a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:25:41.653758 [ 55687 ] {9531cb4b-a60c-47b0-9d30-889c77d37305} executeQuery: Code: 60. DB::Exception: Could not find table: alter_table_9. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54722) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE alter_table_9 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032897f5a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:25:41.672655 [ 55687 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_table_9. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032897f5a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:25:41.980270 [ 55455 ] {344eda7d-290a-4475-b355-51f8640b9c35} executeQuery: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_7). (TABLE_IS_READ_ONLY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53970) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE alter_table_7 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5937: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000387c001e 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:329: DB::StorageReplicatedMergeTree::waitForProcessingQueue(unsigned long, DB::SyncReplicaMode, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000038b01d7c 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6236: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr)::$_1::operator()(String const&) const @ 0x00000000389efc5d 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6296: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000389e9835 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000033858e79 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:25:42.452888 [ 55464 ] {1586e5bd-b5b9-440f-a766-fd470d51c326} executeQuery: Code: 253. DB::Exception: Replica /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_4 already exists. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54642) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 2, line 2) (in query: CREATE TABLE alter_table_4 (`a` UInt8, `b` Int16, `c` Float32, `d` String, `e` Array(UInt8), `f` Nullable(UUID), `g` Tuple(UInt8, UInt16)) ENGINE = ReplicatedMergeTree('/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table', 'r_4') PARTITION BY b % 10 ORDER BY a SETTINGS old_parts_lifetime = 1, cleanup_delay_period = 0, cleanup_delay_period_random_add = 0, cleanup_thread_preferred_points_per_iteration = 0, replicated_max_mutations_in_one_entry = 139, index_granularity = 8192, index_granularity_bytes = '10Mi', min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 508257304, compact_parts_max_bytes_to_buffer = 37929306, compact_parts_max_granules_to_buffer = 182, compact_parts_merge_max_bytes_to_prefetch_part = 24769891, merge_max_block_size = 21489, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 77, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 53305, primary_key_compress_block_size = 57330, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1237: DB::StorageReplicatedMergeTree::createReplicaAttempt(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003882e298 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1087: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&, DB::ZooKeeperRetriesInfo const&) const @ 0x00000000387d372f 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:624: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(DB::TableZnodeInfo const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::ZooKeeperRetriesInfo const&) @ 0x00000000387caf56 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, bool&, DB::ZooKeeperRetriesInfo&, 0>(std::allocator const&, DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, bool&, DB::ZooKeeperRetriesInfo&) @ 0x000000003a38c567 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37ede5 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 09:25:42.687004 [ 55691 ] {3deb008f-8f22-4702-9808-7820dfc99801} executeQuery: Code: 60. DB::Exception: Could not find table: alter_table_8. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54802) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE alter_table_8 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032897f5a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:25:42.913045 [ 53314 ] {0fbef58a-49cc-455c-b460-773fe7349c99} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_7. (TABLE_IS_READ_ONLY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56372) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO alter_table_7 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000003a308e4e 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000003a301d3b 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()::operator()() const @ 0x000000003a3019c9 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000003a30131f 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a2c866d 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a29d717 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2c209b 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 14. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 19. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 2025.06.13 09:25:43.189079 [ 55691 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_table_8. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032897f5a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:25:43.192892 [ 55464 ] {} TCPHandler: Code: 253. DB::Exception: Replica /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_4 already exists. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1237: DB::StorageReplicatedMergeTree::createReplicaAttempt(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003882e298 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1087: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&, DB::ZooKeeperRetriesInfo const&) const @ 0x00000000387d372f 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:624: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(DB::TableZnodeInfo const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::ZooKeeperRetriesInfo const&) @ 0x00000000387caf56 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, bool&, DB::ZooKeeperRetriesInfo&, 0>(std::allocator const&, DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, bool&, DB::ZooKeeperRetriesInfo&) @ 0x000000003a38c567 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a37ede5 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d7be4fa 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000383e72ba 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000003291bacd 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000003290254b 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000003292f3d5 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 23. ? @ 0x00007f5206343ac3 24. ? @ 0x00007f52063d5850 2025.06.13 09:25:43.197179 [ 55455 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_7). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5937: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000387c001e 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:329: DB::StorageReplicatedMergeTree::waitForProcessingQueue(unsigned long, DB::SyncReplicaMode, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000038b01d7c 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6236: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr)::$_1::operator()(String const&) const @ 0x00000000389efc5d 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6296: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000389e9835 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000033858e79 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:25:43.272360 [ 53314 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_7. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000003a308e4e 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000003a301d3b 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()::operator()() const @ 0x000000003a3019c9 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000003a30131f 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a2c866d 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a29d717 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2c209b 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 14. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 19. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:25:43.290057 [ 55766 ] {11993525-9dea-4a55-8d43-6416c8701159} executeQuery: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_7). (TABLE_IS_READ_ONLY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54024) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE alter_table_7 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5937: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000387c001e 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:329: DB::StorageReplicatedMergeTree::waitForProcessingQueue(unsigned long, DB::SyncReplicaMode, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000038b01d7c 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6236: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr)::$_1::operator()(String const&) const @ 0x00000000389efc5d 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6296: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000389e9835 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000033858e79 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:25:43.306461 [ 55766 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_7). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5937: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000387c001e 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:329: DB::StorageReplicatedMergeTree::waitForProcessingQueue(unsigned long, DB::SyncReplicaMode, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000038b01d7c 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6236: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr)::$_1::operator()(String const&) const @ 0x00000000389efc5d 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6296: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000389e9835 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000033858e79 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:25:44.536942 [ 635 ] {} test_ecou59xi.alter_table_6 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_7/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000003ceb1f7a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:635: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003ced9d55 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:283: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a135a23 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a1316e5 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a12dce2 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a15759f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 10. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:44.553169 [ 691 ] {} test_ecou59xi.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_7/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000003ceb1f7a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:635: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003ced9d55 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:283: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a135a23 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a1316e5 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a12dce2 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a15759f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 10. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:44.906285 [ 691 ] {} test_ecou59xi.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_7/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000003ceb1f7a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:635: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003ced9d55 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:283: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a135a23 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a1316e5 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a12dce2 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a15759f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 10. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:44.911153 [ 635 ] {} test_ecou59xi.alter_table_6 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_7/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000003ceb1f7a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:635: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003ced9d55 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:283: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a135a23 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a1316e5 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a12dce2 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a15759f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 10. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:45.056135 [ 1014 ] {} 811164fd-7564-4608-ad04-5dded760420d::0_1_1_1_2 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Transaction failed (No node): Op #12, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_7/parts/0_1_1_1_2. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf01a33 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1602: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf02055 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2202: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x000000003887e6fe 6. ./build_docker/./src/Storages/MergeTree/MergeFromLogEntryTask.cpp:369: DB::MergeFromLogEntryTask::finalize(std::function) @ 0x0000000039679fde 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:233: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a11353d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:45.057345 [ 1014 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {811164fd-7564-4608-ad04-5dded760420d::0_1_1_1_2}: Code: 999. Coordination::Exception: Transaction failed (No node): Op #12, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_7/parts/0_1_1_1_2. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf01a33 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1602: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf02055 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2202: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x000000003887e6fe 6. ./build_docker/./src/Storages/MergeTree/MergeFromLogEntryTask.cpp:369: DB::MergeFromLogEntryTask::finalize(std::function) @ 0x0000000039679fde 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:233: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a11353d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:45.069502 [ 883 ] {} test_ecou59xi.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_7/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000003ceb1f7a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:635: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003ced9d55 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:283: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a135a23 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a1316e5 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a12dce2 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a15759f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 10. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:46.009753 [ 850 ] {} test_ecou59xi.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Transaction failed (Bad version): Op #1, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf01a33 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1602: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf02055 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cede6f0 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:405: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a13b745 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a1316e5 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a12dce2 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a15759f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:46.022648 [ 55673 ] {c3114a37-1ae1-4c31-a834-dc640c1368aa} executeQuery: Code: 341. DB::Exception: Log entry log-0000000016 is not precessed on local replica, most likely because the replica was shut down. (UNFINISHED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57040) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE alter_table_5 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000008bb626d 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7188: DB::StorageReplicatedMergeTree::waitForLogEntryToBeProcessedIfNecessary(DB::ReplicatedMergeTreeLogEntryData const&, std::shared_ptr, String const&) @ 0x00000000389f52fa 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6312: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000389e9284 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000033858e79 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:25:46.032472 [ 55766 ] {b315fd04-a723-4bb9-9bee-3203c2c2e5e5} executeQuery: Code: 60. DB::Exception: Could not find table: alter_table_8. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54282) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE alter_table_8 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032897f5a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:25:46.052341 [ 55766 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_table_8. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032897f5a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:25:46.054021 [ 55673 ] {} TCPHandler: Code: 341. DB::Exception: Log entry log-0000000016 is not precessed on local replica, most likely because the replica was shut down. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000008bb626d 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7188: DB::StorageReplicatedMergeTree::waitForLogEntryToBeProcessedIfNecessary(DB::ReplicatedMergeTreeLogEntryData const&, std::shared_ptr, String const&) @ 0x00000000389f52fa 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6312: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000389e9284 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000033858e79 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:25:46.070139 [ 642 ] {} test_ecou59xi.alter_table_3 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Transaction failed (Bad version): Op #1, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf01a33 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1602: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf02055 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cede6f0 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:405: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a13b745 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a1316e5 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a12dce2 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a15759f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:46.231027 [ 55427 ] {f2718738-287f-4fb3-bf14-ee75e1a46584} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_5. (TABLE_IS_READ_ONLY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53944) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO alter_table_5 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000003a308e4e 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000003a301d3b 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()::operator()() const @ 0x000000003a3019c9 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000003a30131f 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a2c866d 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a29d717 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2c209b 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 14. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 19. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 2025.06.13 09:25:46.357764 [ 55427 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_5. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000003a308e4e 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000003a301d3b 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()::operator()() const @ 0x000000003a3019c9 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000003a30131f 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a2c866d 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a29d717 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2c209b 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 14. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 19. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:25:46.627953 [ 55423 ] {fbe594a3-3bc5-4084-b478-9b21b6b4de8c} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_4. (TABLE_IS_READ_ONLY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54252) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO alter_table_4 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000003a308e4e 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000003a301d3b 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()::operator()() const @ 0x000000003a3019c9 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000003a30131f 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a2c866d 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a29d717 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2c209b 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 14. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 19. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 2025.06.13 09:25:46.800169 [ 55423 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_4. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000003a308e4e 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000003a301d3b 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()::operator()() const @ 0x000000003a3019c9 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000003a30131f 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a2c866d 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a29d717 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2c209b 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 14. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 19. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:25:47.317290 [ 666 ] {} test_ecou59xi.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_4/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000003ceb1f7a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:635: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003ced9d55 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:283: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a135a23 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a1316e5 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a12dce2 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a15759f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 10. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:47.329594 [ 512 ] {} test_ecou59xi.alter_table_6 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_4/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000003ceb1f7a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:635: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003ced9d55 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:283: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a135a23 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a1316e5 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a12dce2 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a15759f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 10. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:47.357813 [ 645 ] {} test_ecou59xi.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_4/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000003ceb1f7a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:635: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003ced9d55 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:283: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a135a23 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a1316e5 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a12dce2 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a15759f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 10. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:47.651148 [ 524 ] {} test_ecou59xi.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_4/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000003ceb1f7a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:635: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003ced9d55 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:283: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a135a23 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a1316e5 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a12dce2 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a15759f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 10. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:47.914127 [ 55685 ] {7e7c0cc9-9491-498d-9141-c06a16ace108} executeQuery: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_5 does not exist. Maybe you meant test_ecou59xi.alter_table_0?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54412) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO alter_table_5 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000329c69b4 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x00000000329e278f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:25:47.933547 [ 55685 ] {} TCPHandler: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_5 does not exist. Maybe you meant test_ecou59xi.alter_table_0?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000329c69b4 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x00000000329e278f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:25:47.994514 [ 55423 ] {5b7e9434-fbd9-4540-901d-f33c6aa2567e} executeQuery: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_4 does not exist. Maybe you meant test_ecou59xi.alter_table_0?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54382) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO alter_table_4 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000329c69b4 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x00000000329e278f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:25:48.005712 [ 55423 ] {} TCPHandler: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_4 does not exist. Maybe you meant test_ecou59xi.alter_table_0?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000329c69b4 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x00000000329e278f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:25:48.785401 [ 593 ] {} test_ecou59xi.alter_table_3 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_4/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000003ceb1f7a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:635: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003ced9d55 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:283: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a135a23 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a1316e5 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a12dce2 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a15759f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 10. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:48.797129 [ 55967 ] {24c42401-f44b-4375-b61f-262fd9913f3b} executeQuery: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_8 does not exist. Maybe you meant test_ecou59xi.alter_table_0?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54454) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO alter_table_8 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000329c69b4 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x00000000329e278f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:25:48.825917 [ 55967 ] {} TCPHandler: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_8 does not exist. Maybe you meant test_ecou59xi.alter_table_0?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000329c69b4 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x00000000329e278f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:25:48.838821 [ 55455 ] {4fbf3515-8f15-4798-90fb-5dc32f258cd1} executeQuery: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_8 does not exist. Maybe you meant test_ecou59xi.alter_table_0?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54460) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO alter_table_8 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000329c69b4 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x00000000329e278f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:25:48.872130 [ 55455 ] {} TCPHandler: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_8 does not exist. Maybe you meant test_ecou59xi.alter_table_0?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000329c69b4 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x00000000329e278f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:25:48.921358 [ 466 ] {} test_ecou59xi.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_4/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000003ceb1f7a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:635: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003ced9d55 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:283: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a135a23 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a1316e5 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a12dce2 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a15759f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 10. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:48.971253 [ 55464 ] {f6e9f013-6579-4215-b959-469b63c4d634} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_5. (TABLE_IS_READ_ONLY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54148) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO alter_table_5 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000003a308e4e 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000003a301d3b 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()::operator()() const @ 0x000000003a3019c9 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000003a30131f 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a2c866d 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a29d717 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2c209b 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 14. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 19. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 2025.06.13 09:25:49.022081 [ 55464 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_5. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000003a308e4e 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000003a301d3b 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()::operator()() const @ 0x000000003a3019c9 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000003a30131f 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a2c866d 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a29d717 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a2c209b 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bd39f49 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003ba0e219 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003ba0dd36 14. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003ba0d14b 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e68ad 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b0aeca3 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b0ae1ba 19. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b0abd00 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 22. ? @ 0x00007f5206343ac3 23. ? @ 0x00007f52063d5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f7c7427 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001f9c90fc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001f9cf59f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001f9d0314 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b0aa5a1 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:25:49.724351 [ 885 ] {} test_ecou59xi.alter_table_6 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_5/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000003ceb1f7a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:635: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003ced9d55 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:283: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a135a23 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a1316e5 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a12dce2 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a15759f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 10. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:49.725643 [ 652 ] {} test_ecou59xi.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_5/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000003ceb1f7a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:635: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003ced9d55 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:283: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a135a23 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a1316e5 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a12dce2 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a15759f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 10. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:49.879569 [ 474 ] {} test_ecou59xi.alter_table_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_5/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000003ceb1f7a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:635: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003ced9d55 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:283: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a135a23 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a1316e5 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a12dce2 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a15759f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 10. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:49.934638 [ 1020 ] {} d4afa4a5-2ac7-410e-9a7f-7e4ee3b7c25d::-1_0_0_0_6 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Transaction failed (No node): Op #14, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_5/parts/-1_0_0_0_6. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf01a33 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1602: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf02055 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2202: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x000000003887e6fe 6. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:241: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000039f8a64d 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:233: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a11353d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:49.937273 [ 1020 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {d4afa4a5-2ac7-410e-9a7f-7e4ee3b7c25d::-1_0_0_0_6}: Code: 999. Coordination::Exception: Transaction failed (No node): Op #14, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_5/parts/-1_0_0_0_6. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf01a33 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1602: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf02055 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2202: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x000000003887e6fe 6. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:241: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000039f8a64d 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:233: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a11353d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:50.104074 [ 739 ] {} test_ecou59xi.alter_table_3 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_5/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000003ceb1f7a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:635: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003ced9d55 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:283: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a135a23 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a1316e5 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a12dce2 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a15759f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 10. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:50.128282 [ 431 ] {} test_ecou59xi.alter_table_2 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_5/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000003ceb1f7a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:635: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003ced9d55 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:283: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a135a23 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a1316e5 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a12dce2 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a15759f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 10. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:50.138564 [ 850 ] {} test_ecou59xi.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_5/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000003ceb1f7a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:635: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003ced9d55 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:283: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a135a23 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a1316e5 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a12dce2 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a15759f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 10. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:50.271061 [ 469 ] {} test_ecou59xi.alter_table_4 (68fa9225-9ff3-4327-bd3e-d271555385f2): Log pointer of source replica r_2 changed while we loading queue nodes. Will retry. 2025.06.13 09:25:50.298492 [ 55969 ] {35ba63d5-68c0-4f0b-ac83-866854a1b5c7} executeQuery: Code: 236. DB::Exception: Shutdown is called for table. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54220) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE alter_table_1 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:9241: DB::StorageReplicatedMergeTree::waitForProcessingQueue(unsigned long, DB::SyncReplicaMode, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000038b023cf 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6236: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr)::$_1::operator()(String const&) const @ 0x00000000389efc5d 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6296: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000389e9835 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000033858e79 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:25:50.337018 [ 55969 ] {} TCPHandler: Code: 236. DB::Exception: Shutdown is called for table. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:9241: DB::StorageReplicatedMergeTree::waitForProcessingQueue(unsigned long, DB::SyncReplicaMode, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000038b023cf 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6236: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr)::$_1::operator()(String const&) const @ 0x00000000389efc5d 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6296: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000389e9835 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000033858e79 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:25:50.365922 [ 55426 ] {b0c0eeeb-4cad-4934-9fad-b37d3d43aaaf} executeQuery: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_5 does not exist. Maybe you meant test_ecou59xi.alter_table_0?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54542) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO alter_table_5 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000329c69b4 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x00000000329e278f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:25:50.380490 [ 55426 ] {} TCPHandler: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_5 does not exist. Maybe you meant test_ecou59xi.alter_table_0?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000329c69b4 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x00000000329e278f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 18. ? @ 0x00007f5206343ac3 19. ? @ 0x00007f52063d5850 2025.06.13 09:25:50.694016 [ 652 ] {} test_ecou59xi.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_5/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000003ceb1f7a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:635: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003ced9d55 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:283: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a135a23 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a1316e5 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a12dce2 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a15759f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 10. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:50.773373 [ 579 ] {} test_ecou59xi.alter_table_6 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_5/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000003ceb1f7a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:635: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003ced9d55 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:283: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a135a23 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a1316e5 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a12dce2 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a15759f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 10. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:51.491158 [ 55969 ] {3a874dd5-afcd-4af8-9e2b-cc9ac44bb03a} executeQuery: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_4). (TABLE_IS_READ_ONLY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54654) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE alter_table_4 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5937: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000387c001e 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6118: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000389e71ad 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000033858e79 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:25:51.544671 [ 55969 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_4). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000adb2fca 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5937: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000387c001e 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6118: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000389e71ad 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000033858e79 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 16. ? @ 0x00007f5206343ac3 17. ? @ 0x00007f52063d5850 2025.06.13 09:25:51.629130 [ 55427 ] {00d64565-50c4-49df-afc7-4c1516870daf} executeQuery: Code: 236. DB::Exception: Log pulling is cancelled. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54380) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE alter_table_1 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:638: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x000000003a1e807f 5. ./build_docker/./src/Storages/MergeTree/Compaction/MergePredicates/ReplicatedMergeTreeMergePredicate.cpp:74: DB::ReplicatedMergeTreeZooKeeperMergePredicate::ReplicatedMergeTreeZooKeeperMergePredicate(DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>) @ 0x000000003a48d729 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::ReplicatedMergeTreeZooKeeperMergePredicate* std::construct_at[abi:ne190107]&, std::optional, std::equal_to, std::allocator>>, DB::ReplicatedMergeTreeZooKeeperMergePredicate*>(DB::ReplicatedMergeTreeZooKeeperMergePredicate*, DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x000000003a26bd6f 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::ReplicatedMergeTreeQueue::getMergePredicate(std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x000000003a23276e 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6175: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr)::$_1::operator()(String const&) const @ 0x00000000389ece9e 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6296: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000389e9835 10. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000033858e79 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 09:25:51.643361 [ 55427 ] {} TCPHandler: Code: 236. DB::Exception: Log pulling is cancelled. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:638: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x000000003a1e807f 5. ./build_docker/./src/Storages/MergeTree/Compaction/MergePredicates/ReplicatedMergeTreeMergePredicate.cpp:74: DB::ReplicatedMergeTreeZooKeeperMergePredicate::ReplicatedMergeTreeZooKeeperMergePredicate(DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>) @ 0x000000003a48d729 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::ReplicatedMergeTreeZooKeeperMergePredicate* std::construct_at[abi:ne190107]&, std::optional, std::equal_to, std::allocator>>, DB::ReplicatedMergeTreeZooKeeperMergePredicate*>(DB::ReplicatedMergeTreeZooKeeperMergePredicate*, DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x000000003a26bd6f 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::ReplicatedMergeTreeQueue::getMergePredicate(std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x000000003a23276e 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6175: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr)::$_1::operator()(String const&) const @ 0x00000000389ece9e 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6296: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000389e9835 10. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000033858e79 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 20. ? @ 0x00007f5206343ac3 21. ? @ 0x00007f52063d5850 2025.06.13 09:25:51.930501 [ 55685 ] {3ea45147-5e63-4978-b022-e9660689ea88} executeQuery: Code: 60. DB::Exception: Could not find table: alter_table_1. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54702) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE alter_table_1 DELETE WHERE cityHash64(a,b,c,d,e,g) % 1048576 < 524288), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032897f5a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:25:51.945390 [ 55685 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_table_1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008beafea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032897f5a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000003288d330 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 2025.06.13 09:25:52.131676 [ 1029 ] {} 510a46ab-4e47-4bd1-8720-9af536529205::-2_0_0_0_37 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Transaction failed (No node): Op #14, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_1/parts/-2_0_0_0_37. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf01a33 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1602: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf02055 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2202: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x000000003887e6fe 6. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:241: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000039f8a64d 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:233: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a11353d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:52.134827 [ 1029 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {510a46ab-4e47-4bd1-8720-9af536529205::-2_0_0_0_37}: Code: 999. Coordination::Exception: Transaction failed (No node): Op #14, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_1/parts/-2_0_0_0_37. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf01a33 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1602: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf02055 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2202: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x000000003887e6fe 6. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:241: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000039f8a64d 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:233: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a11353d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:52.143897 [ 739 ] {} test_ecou59xi.alter_table_3 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Transaction failed (Bad version): Op #7, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf01a33 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1602: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf02055 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cede6f0 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:405: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a13b745 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a1316e5 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a12dce2 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a15759f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:52.160340 [ 807 ] {} test_ecou59xi.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_1/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000003ceb1f7a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:635: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003ced9d55 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:283: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a135a23 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a1316e5 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a12dce2 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a15759f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 10. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:52.267124 [ 872 ] {} test_ecou59xi.alter_table_6 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Can't get data for node '/clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_1/host': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000003ceb1f7a 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:635: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003ced9d55 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:283: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a135a23 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a1316e5 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a12dce2 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a15759f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 10. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:52.421602 [ 1018 ] {} bc49dd58-201a-4655-bee9-314c71974ff8::-2_0_0_0_37 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Transaction failed (No node): Op #12, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_1/parts/-2_0_0_0_37. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf01a33 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1602: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf02055 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2202: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x000000003887e6fe 6. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:241: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000039f8a64d 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:233: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a11353d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:52.424908 [ 1018 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {bc49dd58-201a-4655-bee9-314c71974ff8::-2_0_0_0_37}: Code: 999. Coordination::Exception: Transaction failed (No node): Op #12, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_1/parts/-2_0_0_0_37. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf01a33 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1602: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf02055 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2202: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x000000003887e6fe 6. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:241: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000039f8a64d 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:233: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a11353d 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000003a10f813 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:52.586206 [ 55455 ] {5874d30f-6e04-4fd2-b63c-b542501a6c0c} executeQuery: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_1 does not exist. Maybe you meant test_ecou59xi.alter_table_0?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54752) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE alter_table_1 FINAL SETTINGS receive_timeout=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000003385732a 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:25:52.602934 [ 55455 ] {} TCPHandler: Code: 60. DB::Exception: Table test_ecou59xi.alter_table_1 does not exist. Maybe you meant test_ecou59xi.alter_table_0?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008dc891f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f9f8b45 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000319f7f15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031a0e886 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000003385732a 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033732e25 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000033723599 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x000000003ad8e701 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 17. ? @ 0x00007f5206343ac3 18. ? @ 0x00007f52063d5850 2025.06.13 09:25:53.095463 [ 55673 ] {5488ae9f-60b6-427b-8bc1-0ef453470df7} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54518) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO alter_table_9 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003adff16b 3. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003ade861b 4. ./build_docker/./src/Server/TCPHandler.cpp:692: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003adfc8ee 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003b0aa8fc 6. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 2025.06.13 09:25:53.126162 [ 739 ] {} test_ecou59xi.alter_table_3 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Transaction failed (Bad version): Op #10, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf01a33 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1602: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf02055 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cede6f0 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:405: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a13b745 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a1316e5 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a12dce2 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a15759f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:53.197074 [ 55427 ] {7da2e9e0-7a60-4a57-a230-e98954c93d1a} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54746) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: SELECT * FROM system.parts FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003adff16b 3. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003ade861b 4. ./build_docker/./src/Server/TCPHandler.cpp:1287: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe73a 5. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:25:53.202738 [ 733 ] {} test_ecou59xi.alter_table_0 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Transaction failed (Bad version): Op #10, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf01a33 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1602: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf02055 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cede6f0 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:405: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a13b745 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a1316e5 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a12dce2 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a15759f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:53.251971 [ 431 ] {} test_ecou59xi.alter_table_2 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Transaction failed (Bad version): Op #10, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf01a33 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1602: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf02055 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cede6f0 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:405: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a13b745 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a1316e5 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a12dce2 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a15759f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:53.285986 [ 55427 ] {7da2e9e0-7a60-4a57-a230-e98954c93d1a} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:54746). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2557: DB::TCPHandler::sendException(DB::Exception const&, bool) @ 0x000000003adb5f67 7. ./build_docker/./src/Server/TCPHandler.cpp:825: DB::TCPHandler::runImpl() @ 0x000000003ad8f542 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:53.301142 [ 55427 ] {} TCPHandler: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003adff16b 3. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003ade861b 4. ./build_docker/./src/Server/TCPHandler.cpp:1287: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe73a 5. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 12. ? @ 0x00007f5206343ac3 13. ? @ 0x00007f52063d5850 2025.06.13 09:25:53.318843 [ 660 ] {} test_ecou59xi.alter_table_9 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Transaction failed (Bad version): Op #10, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf01a33 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1602: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf02055 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cede6f0 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:405: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a13b745 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a1316e5 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a12dce2 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a15759f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:53.337110 [ 872 ] {} test_ecou59xi.alter_table_6 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Transaction failed (Bad version): Op #10, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf01a33 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1602: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf02055 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cede6f0 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:405: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a13b745 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a1316e5 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a12dce2 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a15759f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:53.411544 [ 543 ] {} test_ecou59xi.alter_table_7 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Transaction failed (Bad version): Op #10, path: /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. ./src/Common/Exception.h:130: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf01a33 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1602: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cf02055 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1619: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003cede6f0 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:405: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a13b745 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a1316e5 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a12dce2 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a15759f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ea226ad 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002ea2d57c 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002ea2f72f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 15. ? @ 0x00007f5206343ac3 16. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:53.434095 [ 55673 ] {5488ae9f-60b6-427b-8bc1-0ef453470df7} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:54518). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2557: DB::TCPHandler::sendException(DB::Exception const&, bool) @ 0x000000003adb5f67 7. ./build_docker/./src/Server/TCPHandler.cpp:825: DB::TCPHandler::runImpl() @ 0x000000003ad8f542 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:53.454506 [ 55673 ] {} TCPHandler: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003adff16b 3. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003ade861b 4. ./build_docker/./src/Server/TCPHandler.cpp:692: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003adfc8ee 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003b0aa8fc 6. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 2025.06.13 09:25:53.498810 [ 55864 ] {1d91bc60-3311-4eec-bd6b-824be8dd958f} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54640) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO alter_table_6 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003adff16b 3. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003ade861b 4. ./build_docker/./src/Server/TCPHandler.cpp:692: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003adfc8ee 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003b0aa8fc 6. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 2025.06.13 09:25:53.503338 [ 56103 ] {09dc13a3-fecf-422a-883b-061ff305442c} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:54744). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54744) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: SELECT * FROM system.parts FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:1421: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe992 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:25:53.531691 [ 56103 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:54744). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:1421: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003adbe992 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x000000003ad8ea56 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 2025.06.13 09:25:53.551873 [ 55864 ] {1d91bc60-3311-4eec-bd6b-824be8dd958f} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:54640). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2557: DB::TCPHandler::sendException(DB::Exception const&, bool) @ 0x000000003adb5f67 7. ./build_docker/./src/Server/TCPHandler.cpp:825: DB::TCPHandler::runImpl() @ 0x000000003ad8f542 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:53.565910 [ 55864 ] {} TCPHandler: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003adff16b 3. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003ade861b 4. ./build_docker/./src/Server/TCPHandler.cpp:692: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003adfc8ee 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003b0aa8fc 6. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 2025.06.13 09:25:56.473315 [ 1020 ] {} test_ecou59xi.alter_table_0 (ReplicatedMergeTreeQueue): Mutation with version 16 not found in partition ID -2 (trying to mutate part -2_0_0_0_12) 2025.06.13 09:25:56.770225 [ 1029 ] {} test_ecou59xi.alter_table_7 (ReplicatedMergeTreeQueue): Mutation with version 5 not found in partition ID -3 (trying to mutate part -3_0_0_0) 2025.06.13 09:25:57.061352 [ 1016 ] {0368eb18-ae93-48e5-a128-2877016039dd::-3_0_0_0_5} 0368eb18-ae93-48e5-a128-2877016039dd::-3_0_0_0_5 (MutateFromLogEntryTask): Code: 40. DB::Exception: Checksums of parts don't match: hash of uncompressed files doesn't match (bd8fffb4510dd3e01e36f993546e88b4 vs d062872c5f3d2b766b5e5f5f70a38484), uncompressed hash of compressed files doesn't match (3031f62307eb7ba3967b5b06cb78aede vs bd19b3d6ca2ee6c2562da6ba0161fc8b). (CHECKSUM_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)). Data after mutation is not byte-identical to data on another replicas. We will download merged part from replica to force byte-identical result. 2025.06.13 09:25:57.974172 [ 53310 ] {01e5bdaf-6a73-4dbb-a7d7-322295fd645a} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56682) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO alter_table_6 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003adff16b 3. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003ade861b 4. ./build_docker/./src/Server/TCPHandler.cpp:692: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003adfc8ee 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003b0aa8fc 6. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 2025.06.13 09:25:58.270478 [ 53310 ] {01e5bdaf-6a73-4dbb-a7d7-322295fd645a} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:56682). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2557: DB::TCPHandler::sendException(DB::Exception const&, bool) @ 0x000000003adb5f67 7. ./build_docker/./src/Server/TCPHandler.cpp:825: DB::TCPHandler::runImpl() @ 0x000000003ad8f542 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:25:58.283069 [ 53310 ] {} TCPHandler: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003adff16b 3. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003ade861b 4. ./build_docker/./src/Server/TCPHandler.cpp:692: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003adfc8ee 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003b0aa8fc 6. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 2025.06.13 09:26:08.508044 [ 55893 ] {3876c9bf-2324-4086-8f5a-38d455ba1283} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54526) (comment: 00993_system_parts_race_condition_drop_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO alter_table_7 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003adff16b 3. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003ade861b 4. ./build_docker/./src/Server/TCPHandler.cpp:692: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003adfc8ee 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003b0aa8fc 6. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 2025.06.13 09:26:08.648975 [ 55893 ] {3876c9bf-2324-4086-8f5a-38d455ba1283} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:54526). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fbc4e9d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fbc9556 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a9bb8ea 5. DB::WriteBuffer::next() @ 0x0000000008bc3ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2557: DB::TCPHandler::sendException(DB::Exception const&, bool) @ 0x000000003adb5f67 7. ./build_docker/./src/Server/TCPHandler.cpp:825: DB::TCPHandler::runImpl() @ 0x000000003ad8f542 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 14. ? @ 0x00007f5206343ac3 15. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:26:08.660743 [ 55893 ] {} TCPHandler: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003adff16b 3. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003ade861b 4. ./build_docker/./src/Server/TCPHandler.cpp:692: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003adfc8ee 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003b0aa8fc 6. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x000000003ad8f0d8 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x000000003adf609c 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004142b380 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004142c2b2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041310ef5 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004130dcee 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004130a871 13. ? @ 0x00007f5206343ac3 14. ? @ 0x00007f52063d5850 2025.06.13 09:26:12.018099 [ 410 ] {} CgroupsReader: Cannot find 'kernel' in '/sys/fs/cgroup/memory.stat' (skipped 5902 similar messages) 2025.06.13 09:26:12.405676 [ 1014 ] {} test_ecou59xi.alter_table_0 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -1 (trying to mutate part -1_0_0_0 to 6) 2025.06.13 09:26:12.686560 [ 1025 ] {} test_ecou59xi.alter_table_8 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -1 (trying to mutate part -1_0_0_0_6 to 21) 2025.06.13 09:26:12.687146 [ 1016 ] {} test_ecou59xi.alter_table_8 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -2 (trying to mutate part -2_22_22_0_38 to 51) 2025.06.13 09:26:12.693554 [ 1025 ] {} test_ecou59xi.alter_table_8 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -3 (trying to mutate part -3_8_8_0 to 31) 2025.06.13 09:26:12.697056 [ 1016 ] {} test_ecou59xi.alter_table_8 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -3 (trying to mutate part -3_0_0_0_5 to 36) 2025.06.13 09:26:12.697684 [ 1017 ] {defd8ca3-ff62-4887-97f8-b0bb1bd841b6::-1_0_0_0_6} defd8ca3-ff62-4887-97f8-b0bb1bd841b6::-1_0_0_0_6 (MutateFromLogEntryTask): Code: 40. DB::Exception: Checksums of parts don't match: hash of uncompressed files doesn't match (3be0b128fbe1bf85c90eb2ebe764ec76 vs 61dc070d50930fd93cc2e192b03659c3), uncompressed hash of compressed files doesn't match (954bfb787aaa925b92c6923208749bfc vs 71aa5da5500cc269859a3dcf5ab51f78). (CHECKSUM_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)). Data after mutation is not byte-identical to data on another replicas. We will download merged part from replica to force byte-identical result. 2025.06.13 09:26:12.809625 [ 1022 ] {} test_ecou59xi.alter_table_9 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -2 (trying to mutate part -2_0_0_0_16 to 37) 2025.06.13 09:26:12.814942 [ 1021 ] {} test_ecou59xi.alter_table_9 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -1 (trying to mutate part -1_0_0_0_6 to 21) 2025.06.13 09:26:12.816814 [ 1020 ] {} test_ecou59xi.alter_table_9 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -3 (trying to mutate part -3_0_0_0_5 to 36) 2025.06.13 09:26:12.817719 [ 1022 ] {} test_ecou59xi.alter_table_9 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -2 (trying to mutate part -2_22_22_0_38 to 51) 2025.06.13 09:26:12.921556 [ 1025 ] {a13b2a0a-ea97-4e60-be05-e269382a27c8::-3_8_8_0_31} a13b2a0a-ea97-4e60-be05-e269382a27c8::-3_8_8_0_31 (MutateFromLogEntryTask): Code: 40. DB::Exception: Checksums of parts don't match: hash of uncompressed files doesn't match (e41f65512f38a7fb8268a0107f39bccd vs 95d36e18718fa3f775d049b4ccf07c25), uncompressed hash of compressed files doesn't match (bcfb4873901a7ffff46ebb1aae7e89a7 vs 544860917b34d4979ea66166e6343bb0). (CHECKSUM_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)). Data after mutation is not byte-identical to data on another replicas. We will download merged part from replica to force byte-identical result. 2025.06.13 09:26:13.034111 [ 1015 ] {} test_ecou59xi.alter_table_1 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -1 (trying to mutate part -1_0_0_0_6 to 21) 2025.06.13 09:26:13.041105 [ 1015 ] {} test_ecou59xi.alter_table_1 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -2 (trying to mutate part -2_22_22_0_38 to 51) 2025.06.13 09:26:13.047190 [ 1028 ] {} test_ecou59xi.alter_table_1 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -3 (trying to mutate part -3_0_0_0_5 to 36) 2025.06.13 09:26:13.110972 [ 1028 ] {} test_ecou59xi.alter_table_2 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -2 (trying to mutate part -2_0_0_0_16 to 37) 2025.06.13 09:26:13.111221 [ 1015 ] {} test_ecou59xi.alter_table_2 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -2 (trying to mutate part -2_22_22_0 to 38) 2025.06.13 09:26:13.116174 [ 1015 ] {} test_ecou59xi.alter_table_2 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -3 (trying to mutate part -3_8_8_0 to 31) 2025.06.13 09:26:13.116702 [ 1028 ] {} test_ecou59xi.alter_table_2 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -1 (trying to mutate part -1_0_0_0_6 to 21) 2025.06.13 09:26:13.228902 [ 1024 ] {} test_ecou59xi.alter_table_5 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -2 (trying to mutate part -2_22_22_0_38 to 51) 2025.06.13 09:26:13.231487 [ 1020 ] {} test_ecou59xi.alter_table_5 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -3 (trying to mutate part -3_0_0_0_5 to 36) 2025.06.13 09:26:13.287321 [ 1022 ] {d4afa4a5-2ac7-410e-9a7f-7e4ee3b7c25d::-2_22_22_0_38} d4afa4a5-2ac7-410e-9a7f-7e4ee3b7c25d::-2_22_22_0_38 (MutateFromLogEntryTask): Code: 40. DB::Exception: Checksums of parts don't match: hash of uncompressed files doesn't match (b2eaea6e68011e33c25b546276722af7 vs a0847a06158ec210ebb278a6e71ff9b3), uncompressed hash of compressed files doesn't match (f68eb17ab59fc2cc652e744b05d099f7 vs f254441440e3c62e0451a8f045f525aa). (CHECKSUM_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)). Data after mutation is not byte-identical to data on another replicas. We will download merged part from replica to force byte-identical result. 2025.06.13 09:26:13.306518 [ 1028 ] {d4afa4a5-2ac7-410e-9a7f-7e4ee3b7c25d::-3_8_8_0_31} d4afa4a5-2ac7-410e-9a7f-7e4ee3b7c25d::-3_8_8_0_31 (MutateFromLogEntryTask): Code: 40. DB::Exception: Checksums of parts don't match: hash of uncompressed files doesn't match (e41f65512f38a7fb8268a0107f39bccd vs 95d36e18718fa3f775d049b4ccf07c25), uncompressed hash of compressed files doesn't match (bcfb4873901a7ffff46ebb1aae7e89a7 vs 544860917b34d4979ea66166e6343bb0). (CHECKSUM_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)). Data after mutation is not byte-identical to data on another replicas. We will download merged part from replica to force byte-identical result. 2025.06.13 09:26:13.350117 [ 1026 ] {} test_ecou59xi.alter_table_0 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -2 (trying to mutate part -2_0_0_0_16 to 37) 2025.06.13 09:26:13.350479 [ 1024 ] {} test_ecou59xi.alter_table_0 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -3 (trying to mutate part -3_0_0_0 to 5) 2025.06.13 09:26:13.351131 [ 1016 ] {} test_ecou59xi.alter_table_0 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -3 (trying to mutate part -3_8_8_0 to 31) 2025.06.13 09:26:13.354718 [ 1014 ] {} test_ecou59xi.alter_table_0 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -2 (trying to mutate part -2_22_22_0_38 to 51) 2025.06.13 09:26:13.355694 [ 1017 ] {} test_ecou59xi.alter_table_0 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -1 (trying to mutate part -1_0_0_0_6 to 21) 2025.06.13 09:26:13.430755 [ 1024 ] {defd8ca3-ff62-4887-97f8-b0bb1bd841b6::-3_0_0_0_5} defd8ca3-ff62-4887-97f8-b0bb1bd841b6::-3_0_0_0_5 (MutateFromLogEntryTask): Code: 40. DB::Exception: Checksums of parts don't match: hash of uncompressed files doesn't match (bd8fffb4510dd3e01e36f993546e88b4 vs d062872c5f3d2b766b5e5f5f70a38484), uncompressed hash of compressed files doesn't match (3031f62307eb7ba3967b5b06cb78aede vs bd19b3d6ca2ee6c2562da6ba0161fc8b). (CHECKSUM_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)). Data after mutation is not byte-identical to data on another replicas. We will download merged part from replica to force byte-identical result. 2025.06.13 09:26:13.446787 [ 1021 ] {defd8ca3-ff62-4887-97f8-b0bb1bd841b6::-3_8_8_0_31} defd8ca3-ff62-4887-97f8-b0bb1bd841b6::-3_8_8_0_31 (MutateFromLogEntryTask): Code: 40. DB::Exception: Checksums of parts don't match: hash of uncompressed files doesn't match (e41f65512f38a7fb8268a0107f39bccd vs 95d36e18718fa3f775d049b4ccf07c25), uncompressed hash of compressed files doesn't match (bcfb4873901a7ffff46ebb1aae7e89a7 vs 544860917b34d4979ea66166e6343bb0). (CHECKSUM_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)). Data after mutation is not byte-identical to data on another replicas. We will download merged part from replica to force byte-identical result. 2025.06.13 09:26:13.553288 [ 1015 ] {} test_ecou59xi.alter_table_4 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -3 (trying to mutate part -3_8_8_0 to 31) 2025.06.13 09:26:13.553820 [ 1019 ] {} test_ecou59xi.alter_table_4 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -2 (trying to mutate part -2_22_22_0_38 to 51) 2025.06.13 09:26:13.554298 [ 1026 ] {} test_ecou59xi.alter_table_4 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -3 (trying to mutate part -3_0_0_0_5 to 36) 2025.06.13 09:26:13.619567 [ 1026 ] {68fa9225-9ff3-4327-bd3e-d271555385f2::-3_8_8_0_31} 68fa9225-9ff3-4327-bd3e-d271555385f2::-3_8_8_0_31 (MutateFromLogEntryTask): Code: 40. DB::Exception: Checksums of parts don't match: hash of uncompressed files doesn't match (e41f65512f38a7fb8268a0107f39bccd vs 95d36e18718fa3f775d049b4ccf07c25), uncompressed hash of compressed files doesn't match (bcfb4873901a7ffff46ebb1aae7e89a7 vs 544860917b34d4979ea66166e6343bb0). (CHECKSUM_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)). Data after mutation is not byte-identical to data on another replicas. We will download merged part from replica to force byte-identical result. 2025.06.13 09:26:13.650550 [ 1023 ] {} test_ecou59xi.alter_table_3 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -3 (trying to mutate part -3_8_8_0 to 31) 2025.06.13 09:26:13.651706 [ 1018 ] {} test_ecou59xi.alter_table_3 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -1 (trying to mutate part -1_0_0_0_6 to 21) 2025.06.13 09:26:13.651906 [ 1024 ] {} test_ecou59xi.alter_table_3 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -2 (trying to mutate part -2_22_22_0_38 to 51) 2025.06.13 09:26:13.652629 [ 1016 ] {} test_ecou59xi.alter_table_3 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -3 (trying to mutate part -3_0_0_0_5 to 36) 2025.06.13 09:26:13.721330 [ 1024 ] {} test_ecou59xi.alter_table_6 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -3 (trying to mutate part -3_8_8_0 to 31) 2025.06.13 09:26:13.723647 [ 1016 ] {} test_ecou59xi.alter_table_6 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -1 (trying to mutate part -1_0_0_0_6 to 21) 2025.06.13 09:26:13.723779 [ 1027 ] {} test_ecou59xi.alter_table_6 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -2 (trying to mutate part -2_22_22_0_38 to 51) 2025.06.13 09:26:13.724989 [ 1019 ] {} test_ecou59xi.alter_table_6 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -3 (trying to mutate part -3_0_0_0_5 to 36) 2025.06.13 09:26:13.737264 [ 1014 ] {9f85c26c-78c6-4fb2-8e92-760d4112a670::-3_8_8_0_31} 9f85c26c-78c6-4fb2-8e92-760d4112a670::-3_8_8_0_31 (MutateFromLogEntryTask): Code: 40. DB::Exception: Checksums of parts don't match: hash of uncompressed files doesn't match (e41f65512f38a7fb8268a0107f39bccd vs 95d36e18718fa3f775d049b4ccf07c25), uncompressed hash of compressed files doesn't match (bcfb4873901a7ffff46ebb1aae7e89a7 vs 544860917b34d4979ea66166e6343bb0). (CHECKSUM_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)). Data after mutation is not byte-identical to data on another replicas. We will download merged part from replica to force byte-identical result. 2025.06.13 09:26:13.773198 [ 1021 ] {} test_ecou59xi.alter_table_7 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -2 (trying to mutate part -2_0_0_0_16 to 37) 2025.06.13 09:26:13.774651 [ 1017 ] {} test_ecou59xi.alter_table_7 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -3 (trying to mutate part -3_8_8_0 to 31) 2025.06.13 09:26:13.774792 [ 1019 ] {} test_ecou59xi.alter_table_7 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -3 (trying to mutate part -3_0_0_0_5 to 36) 2025.06.13 09:26:13.806050 [ 1018 ] {510a46ab-4e47-4bd1-8720-9af536529205::-3_8_8_0_31} 510a46ab-4e47-4bd1-8720-9af536529205::-3_8_8_0_31 (MutateFromLogEntryTask): Code: 40. DB::Exception: Checksums of parts don't match: hash of uncompressed files doesn't match (e41f65512f38a7fb8268a0107f39bccd vs 95d36e18718fa3f775d049b4ccf07c25), uncompressed hash of compressed files doesn't match (bcfb4873901a7ffff46ebb1aae7e89a7 vs 544860917b34d4979ea66166e6343bb0). (CHECKSUM_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)). Data after mutation is not byte-identical to data on another replicas. We will download merged part from replica to force byte-identical result. 2025.06.13 09:26:13.863665 [ 1021 ] {0368eb18-ae93-48e5-a128-2877016039dd::-3_8_8_0_31} 0368eb18-ae93-48e5-a128-2877016039dd::-3_8_8_0_31 (MutateFromLogEntryTask): Code: 40. DB::Exception: Checksums of parts don't match: hash of uncompressed files doesn't match (e41f65512f38a7fb8268a0107f39bccd vs 95d36e18718fa3f775d049b4ccf07c25), uncompressed hash of compressed files doesn't match (bcfb4873901a7ffff46ebb1aae7e89a7 vs 544860917b34d4979ea66166e6343bb0). (CHECKSUM_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)). Data after mutation is not byte-identical to data on another replicas. We will download merged part from replica to force byte-identical result. 2025.06.13 09:26:14.122257 [ 1026 ] {} test_ecou59xi.alter_table_2 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -3 (trying to mutate part -3_0_0_0_5 to 36) 2025.06.13 09:26:14.123057 [ 1027 ] {} test_ecou59xi.alter_table_2 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -2 (trying to mutate part -2_22_22_0_38 to 51) 2025.06.13 09:26:46.194887 [ 34540 ] {} test_ecou59xi.alter_table_9 (bc49dd58-201a-4655-bee9-314c71974ff8): Table /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_9 is already started to be removing by another replica right now 2025.06.13 09:26:46.195820 [ 4780 ] {} test_ecou59xi.alter_table_0 (defd8ca3-ff62-4887-97f8-b0bb1bd841b6): Table /clickhouse/tables/00993_system_parts_race_condition_drop_zookeeper_test_ecou59xi/alter_table/replicas/r_0 is already started to be removing by another replica right now 2025.06.13 09:29:40.886129 [ 1029 ] {d9dab452-54ad-4671-a57d-5f61798f7cae::all_1_7_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 236. DB::Exception: Cancelled merging parts: While executing MergeTreeSequentialSource. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:106: Poco::Exception::Exception(String const&, int) @ 0x00000000411eada6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f5f5bf2 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008b9f5df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008bc2bc4 4. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x000000003968bba7 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1924: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000396d81bf 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000397168b4 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*, DB::Progress const&) @ 0x00000000397165ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f1bb9e3 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x000000003b0e6ab7 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b0b0ed4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b0afb36 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b0f5b12 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b0f6008 14. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000396c33e0 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000396bdc00 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000396d5401 17. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a471407 18. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003974ac82 19. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003974ca01 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000039753c1f 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9d2ca6 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001f9e6aa6 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001f9e685f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001f9cb587 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001f9deee4 26. ? @ 0x00007f5206343ac3 27. ? @ 0x00007f52063d5850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 09:31:12.005024 [ 410 ] {} CgroupsReader: Cannot find 'kernel' in '/sys/fs/cgroup/memory.stat' (skipped 5897 similar messages) 2025.06.13 09:35:02.089191 [ 398 ] {} Application: Closed all listening sockets. Waiting for 44 outstanding connections. 2025.06.13 09:35:06.997243 [ 398 ] {} Application: Closed connections. But 28 remain. Tip: To increase wait time add to config: 60 2025.06.13 09:35:14.231576 [ 398 ] {} Application: Will shutdown forcefully.